- AbstractAccessDelegate<T extends HazelcastRegion> - Class in com.hazelcast.hibernate.access
- 
Base implementation for consistency guarantees 
- AbstractAccessDelegate(T, Properties) - Constructor for class com.hazelcast.hibernate.access.AbstractAccessDelegate
-  
- AbstractAllPartitionsMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
-  
- AbstractAllPartitionsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractAllPartitionsMessageTask
-  
- AbstractAlterOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-  
- AbstractAlterOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
-  
- AbstractAlterOperation(String, IFunction<Long, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
-  
- AbstractAlterOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-  
- AbstractAlterOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
-  
- AbstractAlterOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
-  
- AbstractAlterRequest - Class in com.hazelcast.concurrent.atomiclong.client
-  
- AbstractAlterRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
-  
- AbstractAlterRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
-  
- AbstractAlterRequest - Class in com.hazelcast.concurrent.atomicreference.client
-  
- AbstractAlterRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.AbstractAlterRequest
-  
- AbstractAlterRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.AbstractAlterRequest
-  
- AbstractBaseReplicatedRecordStore<K,V> - Class in com.hazelcast.replicatedmap.impl.record
- 
Internal base class to encapsulate the internals from the interface methods of ReplicatedRecordStore 
- AbstractBaseReplicatedRecordStore(String, ReplicatedMapService, int) - Constructor for class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-  
- AbstractCacheMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task.cache
- 
Abstract Cache request to handle InMemoryFormat which needed for operation provider 
- AbstractCacheMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.AbstractCacheMessageTask
-  
- AbstractCacheRecord<V> - Class in com.hazelcast.cache.impl.record
- 
Abstract implementation of  CacheRecord with key, value and
 expiration time as internal state. 
- AbstractCacheRecord() - Constructor for class com.hazelcast.cache.impl.record.AbstractCacheRecord
-  
- AbstractCacheRecord(long, long) - Constructor for class com.hazelcast.cache.impl.record.AbstractCacheRecord
-  
- AbstractCacheRecordStore<R extends CacheRecord,CRM extends SampleableCacheRecordMap<Data,R>> - Class in com.hazelcast.cache.impl
-  
- AbstractCacheRecordStore(String, int, NodeEngine, AbstractCacheService) - Constructor for class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- AbstractCacheRecordStore.MaxSizeEvictionChecker - Class in com.hazelcast.cache.impl
-  
- AbstractCacheRecordStore.MaxSizeEvictionChecker() - Constructor for class com.hazelcast.cache.impl.AbstractCacheRecordStore.MaxSizeEvictionChecker
-  
- AbstractCacheRequest - Class in com.hazelcast.cache.impl.client
-  
- AbstractCacheRequest() - Constructor for class com.hazelcast.cache.impl.client.AbstractCacheRequest
-  
- AbstractCacheRequest(String, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.AbstractCacheRequest
-  
- AbstractCacheService - Class in com.hazelcast.cache.impl
-  
- AbstractCacheService() - Constructor for class com.hazelcast.cache.impl.AbstractCacheService
-  
- AbstractCallableMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
- 
Base callable Message task. 
- AbstractCallableMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractCallableMessageTask
-  
- AbstractClientCollectionProxy<E> - Class in com.hazelcast.client.proxy
-  
- AbstractClientCollectionProxy(String, String) - Constructor for class com.hazelcast.client.proxy.AbstractClientCollectionProxy
-  
- AbstractClientSelectionHandler - Class in com.hazelcast.client.connection.nio
-  
- AbstractClientSelectionHandler(ClientConnection, NonBlockingIOThread) - Constructor for class com.hazelcast.client.connection.nio.AbstractClientSelectionHandler
-  
- AbstractClientTxnCollectionProxy<E> - Class in com.hazelcast.client.proxy.txn
-  
- AbstractClientTxnCollectionProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.proxy.txn.AbstractClientTxnCollectionProxy
-  
- AbstractClientTxnCollectionProxy<E> - Class in com.hazelcast.client.txn.proxy
-  
- AbstractClientTxnCollectionProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.txn.proxy.AbstractClientTxnCollectionProxy
-  
- AbstractClusterWideIterator<K,V> - Class in com.hazelcast.cache.impl
- 
- AbstractClusterWideIterator(ICache<K, V>, int) - Constructor for class com.hazelcast.cache.impl.AbstractClusterWideIterator
-  
- AbstractCollectionProxyImpl<S extends RemoteService,E> - Class in com.hazelcast.collection.impl.collection
-  
- AbstractCollectionProxyImpl(String, NodeEngine, S) - Constructor for class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-  
- AbstractCompletableFuture<V> - Class in com.hazelcast.spi.impl
- 
A base  ICompletableFuture implementation that may be explicitly completed by setting its
 value through setResult. 
- AbstractCompletableFuture(NodeEngine, ILogger) - Constructor for class com.hazelcast.spi.impl.AbstractCompletableFuture
-  
- AbstractCompletableFuture(Executor, ILogger) - Constructor for class com.hazelcast.spi.impl.AbstractCompletableFuture
-  
- AbstractConfigBuilder - Class in com.hazelcast.config
- 
Contains logic for replacing system variables in the XML file and importing XML files from different locations. 
- AbstractConfigBuilder() - Constructor for class com.hazelcast.config.AbstractConfigBuilder
-  
- AbstractConfigBuilder.ConfigType - Enum in com.hazelcast.config
-  
- AbstractCredentials - Class in com.hazelcast.security
- 
- AbstractCredentials() - Constructor for class com.hazelcast.security.AbstractCredentials
-  
- AbstractCredentials(String) - Constructor for class com.hazelcast.security.AbstractCredentials
-  
- AbstractDiscoveryStrategy - Class in com.hazelcast.spi.discovery
- 
An common abstract superclass for  DiscoveryStrategy implementations,
 offering convenient access to configuration properties (which may be overridden
 on the system's environment or JVM properties), as well as a  ILogger instance. 
- AbstractDiscoveryStrategy(ILogger, Map<String, Comparable>) - Constructor for class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
-  
- AbstractDistributedObject<S extends RemoteService> - Class in com.hazelcast.spi
- 
Abstract DistributedObject implementation. 
- AbstractDistributedObject(NodeEngine, S) - Constructor for class com.hazelcast.spi.AbstractDistributedObject
-  
- AbstractEntryProcessor<K,V> - Class in com.hazelcast.map
- 
- AbstractEntryProcessor() - Constructor for class com.hazelcast.map.AbstractEntryProcessor
- 
- AbstractEntryProcessor(boolean) - Constructor for class com.hazelcast.map.AbstractEntryProcessor
- 
Creates an AbstractEntryProcessor. 
- AbstractEvictionPolicyEvaluator<A,E extends Evictable> - Class in com.hazelcast.internal.eviction.impl.evaluator
- 
- AbstractEvictionPolicyEvaluator() - Constructor for class com.hazelcast.internal.eviction.impl.evaluator.AbstractEvictionPolicyEvaluator
-  
- AbstractEvictionStrategy<A,E extends Evictable,S extends EvictableStore<A,E>> - Class in com.hazelcast.internal.eviction.impl.strategy
- 
- AbstractEvictionStrategy() - Constructor for class com.hazelcast.internal.eviction.impl.strategy.AbstractEvictionStrategy
-  
- AbstractExecutorServiceCancelMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task.executorservice
-  
- AbstractExecutorServiceCancelMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.AbstractExecutorServiceCancelMessageTask
-  
- AbstractExecutorThreadFactory - Class in com.hazelcast.util.executor
-  
- AbstractExecutorThreadFactory(ThreadGroup, ClassLoader) - Constructor for class com.hazelcast.util.executor.AbstractExecutorThreadFactory
-  
- AbstractHandler - Class in com.hazelcast.nio.tcp.nonblocking
-  
- AbstractHandler(TcpIpConnection, NonBlockingIOThread, int) - Constructor for class com.hazelcast.nio.tcp.nonblocking.AbstractHandler
-  
- AbstractHandler - Class in com.hazelcast.nio.tcp.spinning
-  
- AbstractHandler(TcpIpConnection, ILogger) - Constructor for class com.hazelcast.nio.tcp.spinning.AbstractHandler
-  
- AbstractHazelcastBeanDefinitionParser - Class in com.hazelcast.spring
- 
Base class of all Hazelcast BeanDefinitionParser implementations. 
- AbstractHazelcastBeanDefinitionParser() - Constructor for class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser
-  
- AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper - Class in com.hazelcast.spring
- 
Base Helper class for Spring Xml Builder 
- AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper() - Constructor for class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
-  
- AbstractHazelcastCacheManager - Class in com.hazelcast.cache.impl
- 
Abstract  HazelcastCacheManager (also  CacheManager as indirect) implementation
 provides shared functionality to server and client cache managers. 
- AbstractHazelcastCacheManager(CachingProvider, HazelcastInstance, URI, ClassLoader, Properties) - Constructor for class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- AbstractHazelcastCacheRegionFactory - Class in com.hazelcast.hibernate
- 
Abstract superclass of Hazelcast based RegionFactoryimplementations
 
- AbstractHazelcastCacheRegionFactory() - Constructor for class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
-  
- AbstractHazelcastCacheRegionFactory(Properties) - Constructor for class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
-  
- AbstractHazelcastCacheRegionFactory(HazelcastInstance) - Constructor for class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
-  
- AbstractHazelcastCachingProvider - Class in com.hazelcast.cache.impl
- 
Abstract CachingProviderimplementation providing shared functionality to server and client caching
 providers.
 
- AbstractHazelcastCachingProvider() - Constructor for class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-  
- AbstractICacheEvent - Class in com.hazelcast.cache.impl.event
- 
- AbstractICacheEvent(Object, Member, int) - Constructor for class com.hazelcast.cache.impl.event.AbstractICacheEvent
- 
Constructs a prototypical Cache Event. 
- AbstractIMapEvent - Class in com.hazelcast.core
- 
The abstract class for a map event  IMapEvent. 
- AbstractIMapEvent(Object, Member, int) - Constructor for class com.hazelcast.core.AbstractIMapEvent
- 
Constructs a prototypical map Event. 
- AbstractIndexAwarePredicate - Class in com.hazelcast.query.impl.predicates
-  
- AbstractIndexAwarePredicate() - Constructor for class com.hazelcast.query.impl.predicates.AbstractIndexAwarePredicate
-  
- AbstractIndexAwarePredicate(String) - Constructor for class com.hazelcast.query.impl.predicates.AbstractIndexAwarePredicate
-  
- AbstractInvocationMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
-  
- AbstractInvocationMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractInvocationMessageTask
-  
- AbstractIsLockedRequest - Class in com.hazelcast.concurrent.lock.client
-  
- AbstractIsLockedRequest() - Constructor for class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-  
- AbstractIsLockedRequest(Data) - Constructor for class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-  
- AbstractIsLockedRequest(Data, long) - Constructor for class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-  
- AbstractJob<KeyIn,ValueIn> - Class in com.hazelcast.mapreduce.impl
- 
Base class for all map reduce job implementations 
- AbstractJob(String, JobTracker, KeyValueSource<KeyIn, ValueIn>) - Constructor for class com.hazelcast.mapreduce.impl.AbstractJob
-  
- AbstractJob.MappingJobImpl<EntryKey,Key,Value> - Class in com.hazelcast.mapreduce.impl
- 
This class is just used to comply to the public DSL style API 
- AbstractJob.MappingJobImpl() - Constructor for class com.hazelcast.mapreduce.impl.AbstractJob.MappingJobImpl
-  
- AbstractJob.ReducingJobImpl<EntryKey,Key,Value> - Class in com.hazelcast.mapreduce.impl
- 
This class is just used to comply to the public DSL style API 
- AbstractJob.ReducingJobImpl() - Constructor for class com.hazelcast.mapreduce.impl.AbstractJob.ReducingJobImpl
-  
- AbstractJob.ReducingSubmittableJobImpl<EntryKey,Key,Value> - Class in com.hazelcast.mapreduce.impl
- 
This class is just used to comply to the public DSL style API 
- AbstractJob.ReducingSubmittableJobImpl() - Constructor for class com.hazelcast.mapreduce.impl.AbstractJob.ReducingSubmittableJobImpl
-  
- AbstractJobTracker - Class in com.hazelcast.mapreduce.impl
- 
This is the base class for all  JobTracker implementations on node and client side. 
 It combines a lot of the base functionality to handle remote operations. 
- AbstractJoiner - Class in com.hazelcast.cluster.impl
-  
- AbstractJoiner(Node) - Constructor for class com.hazelcast.cluster.impl.AbstractJoiner
-  
- AbstractLoadBalancer - Class in com.hazelcast.client.util
- 
- AbstractLoadBalancer() - Constructor for class com.hazelcast.client.util.AbstractLoadBalancer
-  
- AbstractLockRequest - Class in com.hazelcast.concurrent.lock.client
-  
- AbstractLockRequest() - Constructor for class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-  
- AbstractLockRequest(Data, long) - Constructor for class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-  
- AbstractLockRequest(Data, long, long, long) - Constructor for class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-  
- AbstractLogger - Class in com.hazelcast.logging
- 
Abstract  ILogger implementation that provides implementations for the convenience methods like
 finest,info,warning and severe. 
- AbstractLogger() - Constructor for class com.hazelcast.logging.AbstractLogger
-  
- AbstractMapAddEntryListenerMessageTask<Parameter> - Class in com.hazelcast.client.impl.protocol.task.map
-  
- AbstractMapAddEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.AbstractMapAddEntryListenerMessageTask
-  
- AbstractMapAddEntryListenerRequest - Class in com.hazelcast.map.impl.client
- 
Base class for adding entry listener to map 
- AbstractMapAddEntryListenerRequest() - Constructor for class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-  
- AbstractMapAddEntryListenerRequest(String, boolean, int) - Constructor for class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-  
- AbstractMapAddEntryListenerRequest(String, Data, boolean, int) - Constructor for class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-  
- AbstractMapDataStore<K,V> - Class in com.hazelcast.map.impl.mapstore
- 
Abstract map data store contains common functionality of map data stores. 
- AbstractMapDataStore(MapStoreWrapper, SerializationService) - Constructor for class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
-  
- AbstractMapPutMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task.map
-  
- AbstractMapPutMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.AbstractMapPutMessageTask
-  
- AbstractMapQueryMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task.map
-  
- AbstractMapQueryMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.AbstractMapQueryMessageTask
-  
- AbstractMapReduceTask<Parameters> - Class in com.hazelcast.client.impl.protocol.task.mapreduce
-  
- AbstractMapReduceTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.mapreduce.AbstractMapReduceTask
-  
- AbstractMember - Class in com.hazelcast.instance
-  
- AbstractMember() - Constructor for class com.hazelcast.instance.AbstractMember
-  
- AbstractMember(Address) - Constructor for class com.hazelcast.instance.AbstractMember
-  
- AbstractMember(Address, String) - Constructor for class com.hazelcast.instance.AbstractMember
-  
- AbstractMember(Address, String, Map<String, Object>) - Constructor for class com.hazelcast.instance.AbstractMember
-  
- AbstractMember(Address, String, Map<String, Object>, boolean) - Constructor for class com.hazelcast.instance.AbstractMember
-  
- AbstractMember(AbstractMember) - Constructor for class com.hazelcast.instance.AbstractMember
-  
- AbstractMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
- 
Base Message task 
- AbstractMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-  
- AbstractMultiMapAddEntryListenerMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task.multimap
-  
- AbstractMultiMapAddEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.AbstractMultiMapAddEntryListenerMessageTask
-  
- AbstractMultiPartitionMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
-  
- AbstractMultiPartitionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractMultiPartitionMessageTask
-  
- AbstractMultiTargetMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
-  
- AbstractMultiTargetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractMultiTargetMessageTask
-  
- AbstractMultiValueGetter - Class in com.hazelcast.query.impl.getters
-  
- AbstractMultiValueGetter(Getter, String, Class<?>, Class) - Constructor for class com.hazelcast.query.impl.getters.AbstractMultiValueGetter
-  
- AbstractMutatingCacheOperation - Class in com.hazelcast.cache.impl.operation
- 
Base class for all mutable cache operations. 
- AbstractMutatingCacheOperation() - Constructor for class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
-  
- AbstractMutatingCacheOperation(String, Data, int) - Constructor for class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
-  
- AbstractNamedOperation - Class in com.hazelcast.spi.impl
-  
- AbstractNamedOperation(String) - Constructor for class com.hazelcast.spi.impl.AbstractNamedOperation
-  
- AbstractNamedOperation() - Constructor for class com.hazelcast.spi.impl.AbstractNamedOperation
-  
- AbstractNearCacheInvalidator - Class in com.hazelcast.map.impl.nearcache
- 
Contains common functionality of a NearCacheInvalidator
 
- AbstractNearCacheInvalidator(MapServiceContext, NearCacheProvider) - Constructor for class com.hazelcast.map.impl.nearcache.AbstractNearCacheInvalidator
-  
- AbstractNearCacheRecord<V> - Class in com.hazelcast.cache.impl.nearcache.impl.record
- 
Abstract implementation of  NearCacheRecord with value and
 expiration time as internal state. 
- AbstractNearCacheRecord(V, long, long) - Constructor for class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-  
- AbstractNearCacheRecordStore<K,V,KS,R extends NearCacheRecord,NCRM extends NearCacheRecordMap<KS,R>> - Class in com.hazelcast.cache.impl.nearcache.impl.store
-  
- AbstractNearCacheRecordStore(NearCacheConfig, NearCacheContext) - Constructor for class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- AbstractNearCacheRecordStore(NearCacheConfig, NearCacheContext, NearCacheStatsImpl) - Constructor for class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- AbstractNearCacheRecordStore.MaxSizeEvictionChecker - Class in com.hazelcast.cache.impl.nearcache.impl.store
-  
- AbstractNearCacheRecordStore.MaxSizeEvictionChecker() - Constructor for class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore.MaxSizeEvictionChecker
-  
- AbstractOperation - Class in com.hazelcast.spi
- 
Abstract  Operation implementation with some basic methods
 implemented. 
- AbstractOperation() - Constructor for class com.hazelcast.spi.AbstractOperation
-  
- AbstractPartitionMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
- 
AbstractPartitionMessageTask 
- AbstractPartitionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractPartitionMessageTask
-  
- AbstractPredicate - Class in com.hazelcast.query.impl.predicates
- 
Provides base features for predicates, such as extraction and convertion of the attribute's value. 
- AbstractPredicate() - Constructor for class com.hazelcast.query.impl.predicates.AbstractPredicate
-  
- AbstractPredicate(String) - Constructor for class com.hazelcast.query.impl.predicates.AbstractPredicate
-  
- AbstractRecord<V> - Class in com.hazelcast.map.impl.record
-  
- AbstractRegionCacheEntryProcessor - Class in com.hazelcast.hibernate.distributed
- 
- AbstractRegionCacheEntryProcessor() - Constructor for class com.hazelcast.hibernate.distributed.AbstractRegionCacheEntryProcessor
-  
- AbstractRemoveListenerMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
- 
Base class for remove listener message tasks that removes a client listener registration
 from a node 
- AbstractRemoveListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractRemoveListenerMessageTask
-  
- AbstractReplicatedMapAddEntryListenerMessageTask<Parameter> - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
-  
- AbstractReplicatedMapAddEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
-  
- AbstractReplicatedMapClientRequest - Class in com.hazelcast.replicatedmap.impl.client
- 
Base class for all ReplicatedMap client request. 
- AbstractReplicatedMapClientRequest() - Constructor for class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-  
- AbstractReplicatedMapClientRequest(String) - Constructor for class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-  
- AbstractReplicatedMapClientRequest(String, int) - Constructor for class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-  
- AbstractReplicatedMapOperation - Class in com.hazelcast.replicatedmap.impl.operation
-  
- AbstractReplicatedMapOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
-  
- AbstractReplicatedRecordStore<K,V> - Class in com.hazelcast.replicatedmap.impl.record
- 
- AbstractReplicatedRecordStore(String, ReplicatedMapService, int) - Constructor for class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-  
- AbstractRingBufferOperation - Class in com.hazelcast.ringbuffer.impl.operations
-  
- AbstractRingBufferOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.AbstractRingBufferOperation
-  
- AbstractRingBufferOperation(String) - Constructor for class com.hazelcast.ringbuffer.impl.operations.AbstractRingBufferOperation
-  
- AbstractSerializationService - Class in com.hazelcast.internal.serialization.impl
-  
- AbstractTextCommand - Class in com.hazelcast.internal.ascii
-  
- AbstractTextCommand(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.internal.ascii.AbstractTextCommand
-  
- AbstractTextCommandProcessor<T> - Class in com.hazelcast.internal.ascii
-  
- AbstractTextCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.AbstractTextCommandProcessor
-  
- AbstractTransactionalCollectionProxy<S extends RemoteService,E> - Class in com.hazelcast.collection.impl.txncollection
-  
- AbstractTransactionalCollectionProxy(String, Transaction, NodeEngine, S) - Constructor for class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
-  
- AbstractTransactionalDataRegion<Cache extends RegionCache> - Class in com.hazelcast.hibernate.region
- 
Abstract base class of all regions 
- AbstractTransactionalDataRegion(HazelcastInstance, String, Properties, CacheDataDescription, Cache) - Constructor for class com.hazelcast.hibernate.region.AbstractTransactionalDataRegion
-  
- AbstractTransactionalMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
-  
- AbstractTransactionalMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractTransactionalMessageTask
-  
- AbstractTxnMapRequest - Class in com.hazelcast.map.impl.client
-  
- AbstractTxnMapRequest() - Constructor for class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-  
- AbstractTxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType) - Constructor for class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-  
- AbstractTxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType, Data) - Constructor for class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-  
- AbstractTxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType, Data, Data) - Constructor for class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-  
- AbstractTxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType, Data, Data, Data) - Constructor for class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-  
- AbstractTxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType, Data, Data, long, TimeUnit) - Constructor for class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-  
- AbstractTxnMapRequest.TxnMapRequestType - Enum in com.hazelcast.map.impl.client
-  
- AbstractUnlockRequest - Class in com.hazelcast.concurrent.lock.client
-  
- AbstractUnlockRequest() - Constructor for class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-  
- AbstractUnlockRequest(Data, long) - Constructor for class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-  
- AbstractUnlockRequest(Data, long, boolean) - Constructor for class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-  
- AbstractVisitor - Class in com.hazelcast.query.impl.predicates
- 
Base class for all visitors. 
- AbstractVisitor() - Constructor for class com.hazelcast.query.impl.predicates.AbstractVisitor
-  
- AbstractWaitNotifyKey - Class in com.hazelcast.spi
- 
Abstract implementation of the WaitNotifyKey. 
- AbstractWaitNotifyKey(String, String) - Constructor for class com.hazelcast.spi.AbstractWaitNotifyKey
-  
- AbstractXmlConfigHelper - Class in com.hazelcast.config
- 
Contains Hazelcast Xml Configuration helper methods and variables. 
- AbstractXmlConfigHelper() - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper
-  
- accept(Visitor, Indexes) - Method in class com.hazelcast.query.impl.predicates.AndPredicate
-  
- accept(Visitor, Indexes) - Method in class com.hazelcast.query.impl.predicates.NotPredicate
-  
- accept(Visitor, Indexes) - Method in class com.hazelcast.query.impl.predicates.OrPredicate
-  
- accept(Visitor, Indexes) - Method in class com.hazelcast.query.SqlPredicate
-  
- accept(Visitor, Indexes) - Method in interface com.hazelcast.query.VisitablePredicate
- 
Accept visitor. 
- accept(int, int, V) - Method in interface com.hazelcast.util.collection.BiInt2ObjectMap.EntryConsumer
- 
A map entry 
- accept(T, U) - Method in interface com.hazelcast.util.function.BiConsumer
- 
Performs this operation on the given arguments. 
- accept(T) - Method in interface com.hazelcast.util.function.Consumer
- 
Performs this operation on the given argument. 
- accept(long, long) - Method in interface com.hazelcast.util.function.LongLongConsumer
- 
Accept a key and value that comes as a tuple of longs. 
- ACCEPT_ALL_SUPPLIER - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- AcceptAllSupplier<KeyIn,ValueIn,ValueOut> - Class in com.hazelcast.mapreduce.aggregation.impl
- 
A standard implementation of the  Supplier
 interface which accepts all input values and may apply a given
  PropertyExtractor on those. 
- AcceptAllSupplier(PropertyExtractor<ValueIn, ValueOut>) - Constructor for class com.hazelcast.mapreduce.aggregation.impl.AcceptAllSupplier
-  
- acceptMasterConfirmation(MemberImpl, long) - Method in class com.hazelcast.cluster.impl.ClusterHeartbeatManager
-  
- acceptVisitor(Predicate[], Visitor, Indexes) - Static method in class com.hazelcast.query.impl.predicates.VisitorUtils
- 
Accept visitor by all predicates. 
- access() - Method in class com.hazelcast.map.impl.nearcache.NearCacheRecord
-  
- access() - Method in class com.hazelcast.map.impl.record.EmptyRecordStatistics
-  
- access() - Method in interface com.hazelcast.map.impl.record.RecordStatistics
-  
- access() - Method in class com.hazelcast.map.impl.record.RecordStatisticsImpl
-  
- access() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-  
- ACCESS_CONTROL - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- AccessDelegate<T extends HazelcastRegion> - Interface in com.hazelcast.hibernate.access
- 
This interface is used to implement basic transactional guarantees 
- accessHit - Variable in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-  
- accessHit - Variable in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-  
- accessRecord(Data, R, ExpiryPolicy, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- accessTime - Variable in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-  
- accessTime - Variable in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-  
- accumulateOrInvalidate(String, Data, List<Data>, String) - Method in class com.hazelcast.map.impl.nearcache.BatchInvalidator
-  
- acquire() - Method in class com.hazelcast.client.proxy.ClientSemaphoreProxy
-  
- acquire(int) - Method in class com.hazelcast.client.proxy.ClientSemaphoreProxy
-  
- acquire(int, String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-  
- acquire() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-  
- acquire(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-  
- acquire() - Method in interface com.hazelcast.core.ISemaphore
- 
Acquires a permit if one is available, and returns immediately,
 reducing the number of available permits by one. 
- acquire(int) - Method in interface com.hazelcast.core.ISemaphore
- 
Acquires the given number of permits if they are available,
 and returns immediately, reducing the number of available permits
 by the given amount. 
- ACQUIRE_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-  
- ACQUIRE_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-  
- AcquireBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
-  
- AcquireBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.AcquireBackupOperation
-  
- AcquireBackupOperation(String, int, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.AcquireBackupOperation
-  
- AcquireOperation - Class in com.hazelcast.concurrent.semaphore.operations
-  
- AcquireOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
-  
- AcquireOperation(String, int, long) - Constructor for class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
-  
- AcquireRequest - Class in com.hazelcast.concurrent.semaphore.client
-  
- AcquireRequest() - Constructor for class com.hazelcast.concurrent.semaphore.client.AcquireRequest
-  
- AcquireRequest(String, int, long) - Constructor for class com.hazelcast.concurrent.semaphore.client.AcquireRequest
-  
- AcquireRequest(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.client.AcquireRequest
-  
- AcquireRequest(String) - Constructor for class com.hazelcast.concurrent.semaphore.client.AcquireRequest
-  
- ACTION_ACQUIRE - Static variable in class com.hazelcast.security.permission.ActionConstants
-  
- ACTION_ADD - Static variable in class com.hazelcast.security.permission.ActionConstants
-  
- ACTION_ALL - Static variable in class com.hazelcast.security.permission.ActionConstants
-  
- ACTION_CREATE - Static variable in class com.hazelcast.security.permission.ActionConstants
-  
- ACTION_DESTROY - Static variable in class com.hazelcast.security.permission.ActionConstants
-  
- ACTION_INDEX - Static variable in class com.hazelcast.security.permission.ActionConstants
-  
- ACTION_INTERCEPT - Static variable in class com.hazelcast.security.permission.ActionConstants
-  
- ACTION_LISTEN - Static variable in class com.hazelcast.security.permission.ActionConstants
-  
- ACTION_LOCK - Static variable in class com.hazelcast.security.permission.ActionConstants
-  
- ACTION_MODIFY - Static variable in class com.hazelcast.security.permission.ActionConstants
-  
- ACTION_PUBLISH - Static variable in class com.hazelcast.security.permission.ActionConstants
-  
- ACTION_PUT - Static variable in class com.hazelcast.security.permission.ActionConstants
-  
- ACTION_READ - Static variable in class com.hazelcast.security.permission.ActionConstants
-  
- ACTION_RELEASE - Static variable in class com.hazelcast.security.permission.ActionConstants
-  
- ACTION_REMOVE - Static variable in class com.hazelcast.security.permission.ActionConstants
-  
- ActionConstants - Class in com.hazelcast.security.permission
-  
- actions - Variable in class com.hazelcast.security.permission.InstancePermission
-  
- activate() - Method in interface com.hazelcast.osgi.impl.HazelcastInternalOSGiService
- 
Activates the service. 
- Activator - Class in com.hazelcast.osgi.impl
- 
Hazelcast OSGi bundle activator. 
- Activator() - Constructor for class com.hazelcast.osgi.impl.Activator
-  
- activeConnectionCount - Variable in class com.hazelcast.internal.management.dto.ConnectionManagerDTO
-  
- add(E) - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
-  
- add(int, E) - Method in class com.hazelcast.client.proxy.ClientListProxy
-  
- add(E) - Method in class com.hazelcast.client.proxy.ClientListProxy
-  
- add(E) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-  
- add(E) - Method in class com.hazelcast.client.proxy.ClientRingbufferProxy
-  
- add(E) - Method in class com.hazelcast.client.proxy.ClientSetProxy
-  
- add(E) - Method in class com.hazelcast.client.proxy.txn.ClientTxnListProxy
-  
- add(E) - Method in class com.hazelcast.client.proxy.txn.ClientTxnSetProxy
-  
- add(E) - Method in class com.hazelcast.client.txn.proxy.ClientTxnListProxy
-  
- add(E) - Method in class com.hazelcast.client.txn.proxy.ClientTxnSetProxy
-  
- add(M) - Method in class com.hazelcast.cluster.impl.MemberSelectingCollection
-  
- add(E) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-  
- add(Data) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- add(int, Data) - Method in class com.hazelcast.collection.impl.list.ListContainer
-  
- add(int, E) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
-  
- add(E) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
-  
- add(E) - Method in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
-  
- add(E) - Method in class com.hazelcast.collection.impl.txnset.TransactionalSetProxy
-  
- add(CountDownLatchContainer) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-  
- add(E) - Method in interface com.hazelcast.core.TransactionalList
- 
Adds a new item to the transactional list. 
- add(E) - Method in interface com.hazelcast.core.TransactionalSet
- 
Add new item to transactional set. 
- add(Map.Entry<Data, Data>) - Method in class com.hazelcast.map.impl.MapEntries
-  
- add(Data, Data) - Method in class com.hazelcast.map.impl.MapEntries
-  
- add(K, V, long) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
-  
- add(Data, Object, long) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-  
- add(DelayedEntry<Data, Object>) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-  
- add(Data, Object, long) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
-  
- add(SingleNearCacheInvalidation) - Method in class com.hazelcast.map.impl.nearcache.BatchNearCacheInvalidation
-  
- add(long) - Method in class com.hazelcast.map.impl.nearcache.NearCacheSizeEstimator
-  
- add(long) - Method in interface com.hazelcast.map.impl.SizeEstimator
-  
- add(QueryableEntry) - Method in class com.hazelcast.query.impl.FastMultiResultSet
-  
- add(T) - Method in class com.hazelcast.query.impl.getters.MultiResult
-  
- add(Map.Entry<Data, Data>) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
-  
- add(Data, Data) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
-  
- ADD - Static variable in class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
-  
- add(Object) - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
-  
- add(Data) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-  
- add(E) - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
-  
- add(E) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
- 
Adds an item to the tail of the Ringbuffer. 
- add(Permission) - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
-  
- add(Permission) - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
-  
- add(PermissionCollection) - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
-  
- add(Permission) - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
-  
- add(Object) - Method in class com.hazelcast.spi.impl.operationexecutor.classic.DefaultScheduleQueue
-  
- add(Object) - Method in interface com.hazelcast.spi.impl.operationexecutor.classic.ScheduleQueue
- 
Adds an task with normal priority to this queue. 
- add(TransactionLogRecord) - Method in interface com.hazelcast.transaction.impl.Transaction
-  
- add(TransactionLogRecord) - Method in class com.hazelcast.transaction.impl.TransactionImpl
-  
- add(TransactionLogRecord) - Method in class com.hazelcast.transaction.impl.TransactionLog
-  
- add(TransactionLogRecord) - Method in class com.hazelcast.transaction.impl.xa.XATransaction
-  
- add(T) - Method in class com.hazelcast.util.collection.InflatableSet
-  
- add(T) - Method in class com.hazelcast.util.collection.InflatableSet.Builder
-  
- add(Integer) - Method in class com.hazelcast.util.collection.IntHashSet
- add(int) - Method in class com.hazelcast.util.collection.IntHashSet
- 
Primitive specialised overload of {this#add(Integer)} 
- add(Long) - Method in class com.hazelcast.util.collection.LongHashSet
- add(long) - Method in class com.hazelcast.util.collection.LongHashSet
- 
Primitive specialised overload of {this#add(Long)} 
- add(T, long) - Method in class com.hazelcast.util.ItemCounter
- 
Add delta to the item 
- add(E) - Method in class com.hazelcast.util.UnmodifiableListIterator
-  
- ADD_ALL - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-  
- ADD_ALL - Static variable in class com.hazelcast.collection.impl.queue.QueuePortableHook
-  
- ADD_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- ADD_ALL - Static variable in class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
-  
- ADD_ALL_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-  
- ADD_ALL_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- ADD_ALL_BACKUP_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
-  
- ADD_ALL_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
-  
- ADD_AND_GET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-  
- ADD_BACKUP - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-  
- ADD_BACKUP_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
-  
- ADD_CACHE_PARTITION_LOST_LISTENER - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- ADD_ENTRY_LISTENER - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- ADD_ENTRY_LISTENER - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- ADD_ENTRY_LISTENER - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-  
- ADD_ENTRY_LISTENER_SQL - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- ADD_INDEX - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- ADD_INTERCEPTOR - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- ADD_INVALIDATION_LISTENER - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- ADD_LISTENER - Static variable in class com.hazelcast.collection.impl.queue.QueuePortableHook
-  
- ADD_LISTENER - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-  
- ADD_LISTENER - Static variable in class com.hazelcast.topic.impl.TopicPortableHook
-  
- ADD_MAP_PARTITION_LOST_LISTENER - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- ADD_NEAR_CACHE_ENTRY_LISTENER - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- ADD_NEAR_CACHE_ENTRY_LISTENER - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-  
- ADD_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
-  
- ADD_PARTITION_LOST_LISTENER - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-  
- addAction(String) - Method in class com.hazelcast.config.PermissionConfig
-  
- addAddress(String...) - Method in class com.hazelcast.client.config.ClientConfig
- 
Deprecated. 
- addAddress(String...) - Method in class com.hazelcast.client.config.ClientNetworkConfig
- 
Adds given addresses to candidate address list that client will use to establish initial connection 
- addAll(Collection<? extends E>) - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
-  
- addAll(int, Collection<? extends E>) - Method in class com.hazelcast.client.proxy.ClientListProxy
-  
- addAll(Collection<? extends E>) - Method in class com.hazelcast.client.proxy.ClientListProxy
-  
- addAll(Collection<? extends E>) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-  
- addAll(Collection<? extends E>) - Method in class com.hazelcast.client.proxy.ClientSetProxy
-  
- addAll(Collection<? extends M>) - Method in class com.hazelcast.cluster.impl.MemberSelectingCollection
-  
- addAll(Collection<? extends E>) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-  
- addAll(List<Data>) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- addAll(int, List<Data>) - Method in class com.hazelcast.collection.impl.list.ListContainer
-  
- addAll(int, Collection<? extends E>) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
-  
- addAll(Collection<Data>) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- addAll(Collection<? extends E>) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
-  
- addAll(List<Data>) - Method in class com.hazelcast.collection.impl.set.SetContainer
-  
- addAll(Collection<QueryableEntry>) - Method in class com.hazelcast.map.impl.query.QueryResult
-  
- addAll(Data[]) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-  
- addAll(Collection<? extends Integer>) - Method in class com.hazelcast.util.collection.IntHashSet
- addAll(Collection<? extends Long>) - Method in class com.hazelcast.util.collection.LongHashSet
- addAllAsync(Collection<? extends E>, OverflowPolicy) - Method in class com.hazelcast.client.proxy.ClientRingbufferProxy
-  
- addAllAsync(Collection<? extends E>, OverflowPolicy) - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
-  
- addAllAsync(Collection<? extends E>, OverflowPolicy) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
- 
Adds all the items of a collection to the tail of the Ringbuffer. 
- addAllBackup(Map<Long, Data>) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- addAllBackup(Map<Long, Data>) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- AddAllBackupOperation - Class in com.hazelcast.collection.impl.queue.operations
- 
- AddAllBackupOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.AddAllBackupOperation
-  
- AddAllBackupOperation(String, Map<Long, Data>) - Constructor for class com.hazelcast.collection.impl.queue.operations.AddAllBackupOperation
-  
- AddAllBackupOperation - Class in com.hazelcast.ringbuffer.impl.operations
-  
- AddAllBackupOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddAllBackupOperation
-  
- AddAllBackupOperation(String, Data[]) - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddAllBackupOperation
-  
- AddAllOperation - Class in com.hazelcast.collection.impl.queue.operations
- 
Add collection items to the Queue. 
- AddAllOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.AddAllOperation
-  
- AddAllOperation(String, Collection<Data>) - Constructor for class com.hazelcast.collection.impl.queue.operations.AddAllOperation
-  
- AddAllOperation - Class in com.hazelcast.ringbuffer.impl.operations
-  
- AddAllOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
-  
- AddAllOperation(String, Data[], OverflowPolicy) - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
-  
- AddAllRequest - Class in com.hazelcast.collection.impl.queue.client
- 
- AddAllRequest() - Constructor for class com.hazelcast.collection.impl.queue.client.AddAllRequest
-  
- AddAllRequest(String, Collection<Data>) - Constructor for class com.hazelcast.collection.impl.queue.client.AddAllRequest
-  
- AddAllRequest - Class in com.hazelcast.ringbuffer.impl.client
-  
- AddAllRequest() - Constructor for class com.hazelcast.ringbuffer.impl.client.AddAllRequest
-  
- AddAllRequest(String, Data[], OverflowPolicy) - Constructor for class com.hazelcast.ringbuffer.impl.client.AddAllRequest
-  
- addAllRows(Collection<QueryResultRow>) - Method in class com.hazelcast.map.impl.query.QueryResult
-  
- addAllRows(Collection<QueryResultRow>) - Method in class com.hazelcast.map.impl.query.QueryResultCollection
-  
- addAndGet(long) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-  
- addAndGet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
-  
- addAndGet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- addAndGet(long) - Method in interface com.hazelcast.core.IAtomicLong
- 
Atomically adds the given value to the current value. 
- addAndGet(long) - Method in class com.hazelcast.jmx.AtomicLongMBean
-  
- AddAndGetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-  
- AddAndGetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
-  
- AddAndGetOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
-  
- AddAndGetRequest - Class in com.hazelcast.concurrent.atomiclong.client
-  
- AddAndGetRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.AddAndGetRequest
-  
- AddAndGetRequest(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.client.AddAndGetRequest
-  
- addAsync(E, OverflowPolicy) - Method in class com.hazelcast.client.proxy.ClientRingbufferProxy
-  
- addAsync(E, OverflowPolicy) - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
-  
- addAsync(E, OverflowPolicy) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
- 
- addAwait(Data, String, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- addBackup(long, Data) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- addBackup(K, V, long) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
-  
- addBackup(Data, Object, long) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-  
- addBackup(Data, Object, long) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
-  
- AddBackupOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-  
- AddBackupOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
-  
- AddBackupOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
-  
- AddBackupOperation - Class in com.hazelcast.ringbuffer.impl.operations
-  
- AddBackupOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddBackupOperation
-  
- AddBackupOperation(String, Data) - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddBackupOperation
-  
- addBooleanArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addBooleanField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addByteArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addByteField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addCacheConfig(CacheConfig) - Method in class com.hazelcast.cache.impl.operation.PostJoinCacheOperation
-  
- addCacheConfig(CacheSimpleConfig) - Method in class com.hazelcast.config.Config
-  
- addCacheConfigIfAbsent(CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- addCacheConfigIfAbsent(CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-  
- addCacheConfigIfAbsent(CacheConfig<K, V>) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
-  
- addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in interface com.hazelcast.config.CacheConfiguration
- 
Add a configuration for a CacheEntryListener.
 
- addCachePartitionLostListenerConfig(CachePartitionLostListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Adds the CachePartitionLostListenerConfig to partitionLostListenerConfigs. 
- addCachePartitionLostListenerConfig(CachePartitionLostListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- addCacheResource(String, Closeable) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- addCharArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addCharField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addClassDefinition(ClassDefinition) - Method in class com.hazelcast.config.SerializationConfig
-  
- addClassDefinition(ClassDefinition) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- addClassDefinition(ClassDefinition) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
-  
- addClientListener(ClientListener) - Method in class com.hazelcast.client.impl.ClientServiceProxy
-  
- addClientListener(ClientListener) - Method in interface com.hazelcast.core.ClientService
- 
Adds a ClientListener. 
- addClientLoginModuleConfig(LoginModuleConfig) - Method in class com.hazelcast.config.SecurityConfig
-  
- addClientPermissionConfig(PermissionConfig) - Method in class com.hazelcast.config.SecurityConfig
-  
- addComponents(List<String>, Map<String, String>, String) - Method in class com.hazelcast.aws.security.EC2RequestSigner
-  
- addConnection(TcpIpConnection) - Method in class com.hazelcast.nio.tcp.spinning.SpinningInputThread
-  
- addConnection(TcpIpConnection) - Method in class com.hazelcast.nio.tcp.spinning.SpinningOutputThread
-  
- addConnectionEventListener(ConnectionEventListener) - Method in class com.hazelcast.jca.ManagedConnectionImpl
-  
- addConnectionHeartbeatListener(ConnectionHeartbeatListener) - Method in interface com.hazelcast.client.connection.ClientConnectionManager
-  
- addConnectionHeartbeatListener(ConnectionHeartbeatListener) - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-  
- addConnectionListener(ConnectionListener) - Method in interface com.hazelcast.client.connection.ClientConnectionManager
-  
- addConnectionListener(ConnectionListener) - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-  
- addConnectionListener(ConnectionListener) - Method in interface com.hazelcast.nio.ConnectionManager
- 
Registers a ConnectionListener. 
- addConnectionListener(ConnectionListener) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- addContainer(String, CollectionContainer) - Method in class com.hazelcast.collection.impl.collection.CollectionService
-  
- addContainer(String, QueueContainer) - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- addDataSerializableFactory(int, DataSerializableFactory) - Method in class com.hazelcast.config.SerializationConfig
-  
- addDataSerializableFactory(int, DataSerializableFactory) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- addDataSerializableFactory(int, DataSerializableFactory) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
-  
- addDataSerializableFactoryClass(int, String) - Method in class com.hazelcast.config.SerializationConfig
-  
- addDataSerializableFactoryClass(int, Class<? extends DataSerializableFactory>) - Method in class com.hazelcast.config.SerializationConfig
-  
- addDestroyAction(String, Callable<Boolean>) - Method in interface com.hazelcast.client.ClientEndpoint
- 
Adds a remove callable to be called when endpoint is destroyed
 Note: removeDestroyAction should be called when there is no need to destroy action anymore. 
- addDestroyAction(String, Callable<Boolean>) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- addDiscoveryStrategyConfig(DiscoveryStrategyConfig) - Method in class com.hazelcast.config.DiscoveryConfig
- 
- addDiscoveryStrategyConfig(DiscoveryStrategyConfig) - Method in class com.hazelcast.config.DiscoveryConfigReadOnly
-  
- addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.client.spi.ProxyManager
-  
- addDistributedObjectListener(DistributedObjectListener) - Method in interface com.hazelcast.core.HazelcastInstance
- 
Adds a Distributed Object listener which will be notified when a
 new  DistributedObject will be created or destroyed. 
- addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- AddDistributedObjectListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task
-  
- AddDistributedObjectListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
-  
- AddDistributedObjectListenerRequest - Class in com.hazelcast.client.impl.client
-  
- AddDistributedObjectListenerRequest() - Constructor for class com.hazelcast.client.impl.client.AddDistributedObjectListenerRequest
-  
- addDoubleArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addDoubleField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addEndpoint(String) - Method in class com.hazelcast.config.PermissionConfig
-  
- addEndpoint(String) - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- addEntryListener(MapListener, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- addEntryListener(EntryListener, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- addEntryListener(MapListener, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- addEntryListener(EntryListener, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- addEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- addEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- addEntryListener(EntryListener<K, V>, boolean) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-  
- addEntryListener(EntryListener<K, V>, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-  
- addEntryListener(EntryListener<K, V>) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-  
- addEntryListener(EntryListener<K, V>, K) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-  
- addEntryListener(EntryListener<K, V>, Predicate<K, V>) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-  
- addEntryListener(EntryListener<K, V>, Predicate<K, V>, K) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-  
- addEntryListener(MapListener, boolean) - Method in interface com.hazelcast.core.IMap
- 
- addEntryListener(EntryListener, boolean) - Method in interface com.hazelcast.core.IMap
- 
- addEntryListener(MapListener, K, boolean) - Method in interface com.hazelcast.core.IMap
- 
- addEntryListener(EntryListener, K, boolean) - Method in interface com.hazelcast.core.IMap
- 
- addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
- 
- addEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
- 
- addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
- 
- addEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
- 
- addEntryListener(EntryListener<K, V>, boolean) - Method in interface com.hazelcast.core.MultiMap
- 
Adds an entry listener for this multimap. 
- addEntryListener(EntryListener<K, V>, K, boolean) - Method in interface com.hazelcast.core.MultiMap
- 
Adds the specified entry listener for the specified key. 
- addEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.core.ReplicatedMap
- 
Adds an entry listener for this map. 
- addEntryListener(EntryListener<K, V>, K) - Method in interface com.hazelcast.core.ReplicatedMap
- 
Adds the specified entry listener for the specified key. 
- addEntryListener(EntryListener<K, V>, Predicate<K, V>) - Method in interface com.hazelcast.core.ReplicatedMap
- 
Adds an continuous entry listener for this map. 
- addEntryListener(EntryListener<K, V>, Predicate<K, V>, K) - Method in interface com.hazelcast.core.ReplicatedMap
- 
Adds an continuous entry listener for this map. 
- addEntryListener(MapListener, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- addEntryListener(EntryListener, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- addEntryListener(MapListener, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- addEntryListener(EntryListener, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- addEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- addEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- addEntryListener(MapListener, boolean) - Method in interface com.hazelcast.map.QueryCache
-  
- addEntryListener(MapListener, K, boolean) - Method in interface com.hazelcast.map.QueryCache
-  
- addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.QueryCache
-  
- addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.map.QueryCache
-  
- addEntryListener(EntryListener<K, V>, boolean) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-  
- addEntryListener(EntryListener<K, V>, K, boolean) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-  
- addEntryListener(EntryListener<K, V>) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-  
- addEntryListener(EntryListener<K, V>, K) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-  
- addEntryListener(EntryListener<K, V>, Predicate<K, V>) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-  
- addEntryListener(EntryListener<K, V>, Predicate<K, V>, K) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-  
- addEntryListenerConfig(CacheSimpleEntryListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
- addEntryListenerConfig(CacheSimpleEntryListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MapConfig
-  
- addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MultiMapConfig
- 
Adds an entry listener to this MultiMap (listens for when entries are added or removed). 
- addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-  
- addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.QueryCacheConfig
- 
- addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.ReplicatedMapConfig
-  
- AddEntryListenerRequest - Class in com.hazelcast.multimap.impl.client
-  
- AddEntryListenerRequest() - Constructor for class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-  
- AddEntryListenerRequest(String, Data, boolean) - Constructor for class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-  
- addEventData(CacheEventData) - Method in class com.hazelcast.cache.impl.CacheEventSet
- 
Helper method for adding multiple CacheEventData into this Set 
- addEventHandler(long, EventHandler) - Method in class com.hazelcast.client.spi.impl.listener.ClientListenerServiceImpl
-  
- addEventListener(Object, EventFilter, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
-  
- addEventListener(EventListener, EventFilter, String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapEventPublishingService
-  
- addExecutorConfig(ExecutorConfig) - Method in class com.hazelcast.config.Config
- 
Adds a new ExecutorConfig by name 
- addField(FieldDefinitionImpl) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addFieldDef(FieldDefinitionImpl) - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-  
- addFilter(String) - Method in class com.hazelcast.config.WanReplicationRef
-  
- addFirst(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
- 
Inserts collection of elements to the front of this queue. 
- addFlag(short) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
- 
Sets the flags field value. 
- addFloatArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addFloatField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addGetTimeNanos(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
- 
Increments the getCache time accumulator. 
- addIndex(String, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- addIndex(String, boolean) - Method in interface com.hazelcast.core.IMap
- 
Adds an index to this map for the specified entries so
 that queries can run faster. 
- addIndex(String, boolean) - Method in interface com.hazelcast.map.QueryCache
-  
- addIndexConfig(MapIndexConfig) - Method in class com.hazelcast.config.QueryCacheConfig
-  
- AddIndexOperation - Class in com.hazelcast.map.impl.operation
-  
- AddIndexOperation() - Constructor for class com.hazelcast.map.impl.operation.AddIndexOperation
-  
- AddIndexOperation(String, String, boolean) - Constructor for class com.hazelcast.map.impl.operation.AddIndexOperation
-  
- AddIndexOperationFactory - Class in com.hazelcast.map.impl.operation
-  
- AddIndexOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.AddIndexOperationFactory
-  
- AddIndexOperationFactory(String, String, boolean) - Constructor for class com.hazelcast.map.impl.operation.AddIndexOperationFactory
-  
- addIntArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addInterceptor(MapInterceptor) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- addInterceptor(MapInterceptor) - Method in interface com.hazelcast.core.IMap
- 
Adds an interceptor for this map. 
- addInterceptor(String, String, MapInterceptor) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
-  
- addInterceptor(MapInterceptor) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- AddInterceptorOperation - Class in com.hazelcast.map.impl.operation
-  
- AddInterceptorOperation() - Constructor for class com.hazelcast.map.impl.operation.AddInterceptorOperation
-  
- AddInterceptorOperation(String, MapInterceptor, String) - Constructor for class com.hazelcast.map.impl.operation.AddInterceptorOperation
-  
- AddInterceptorOperationFactory - Class in com.hazelcast.map.impl.operation
-  
- AddInterceptorOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.AddInterceptorOperationFactory
-  
- AddInterceptorOperationFactory(String, String, MapInterceptor) - Constructor for class com.hazelcast.map.impl.operation.AddInterceptorOperationFactory
-  
- addInterface(String) - Method in class com.hazelcast.config.InterfacesConfig
- 
Adds a new interface 
- addInterface(String) - Method in class com.hazelcast.config.MemberGroupConfig
- 
Adds an interface to the member group. 
- addIntField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addInvalidationListener(String, CacheEventListener, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
- 
- addInvalidationListener(String, CacheEventListener, boolean) - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- addInvalidationMessage(CacheSingleInvalidationMessage) - Method in class com.hazelcast.cache.impl.client.CacheBatchInvalidationMessage
-  
- addItem(Object) - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
-  
- addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
-  
- addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.client.proxy.ClientListProxy
-  
- addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-  
- addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.client.proxy.ClientSetProxy
-  
- addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-  
- addItemListener(String, ItemListener, boolean, boolean) - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- addItemListener(ItemListener<E>, boolean) - Method in interface com.hazelcast.core.ICollection
- 
Adds an item listener for this collection. 
- addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.CollectionConfig
- 
Adds an item listener to this collection (listens for when items are added or removed). 
- addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.ListConfigReadOnly
-  
- addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.QueueConfig
- 
Add an item listener configuration to this queue. 
- addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.QueueConfigReadOnly
-  
- addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.SetConfigReadOnly
-  
- addJobTrackerConfig(JobTrackerConfig) - Method in class com.hazelcast.config.Config
-  
- addLast(E) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
- 
Inserts to the end of this queue. 
- addLifecycleListener(LifecycleListener) - Method in class com.hazelcast.client.impl.LifecycleServiceImpl
-  
- addLifecycleListener(LifecycleListener) - Method in interface com.hazelcast.core.LifecycleService
- 
Add a listener object to listen for lifecycle events. 
- addLifecycleListener(LifecycleListener) - Method in class com.hazelcast.instance.LifecycleServiceImpl
-  
- addLifecycleListener(LifecycleListener) - Method in class com.hazelcast.instance.TerminatedLifecycleService
-  
- addListConfig(ListConfig) - Method in class com.hazelcast.config.Config
-  
- addListener(String, EventListener, Data, boolean, boolean) - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- addListenerConfig(ListenerConfig) - Method in class com.hazelcast.client.config.ClientConfig
- 
Helper method to add a new ListenerConfig 
- addListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.Config
-  
- addListenerConfig(QuorumListenerConfig) - Method in class com.hazelcast.config.QuorumConfig
-  
- addListenerDestroyAction(String, String, String) - Method in interface com.hazelcast.client.ClientEndpoint
- 
Adds a remove callable to be called when endpoint is destroyed to clean related listener
 Following line will be called when endpoint destroyed :
 eventService.deregisterListener(service, topic, id);
 Note: removeDestroyAction should be called when there is no need to destroy action anymore. 
- addListenerDestroyAction(String, String, String) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- AddListenerRequest - Class in com.hazelcast.collection.impl.queue.client
- 
this class is used to attach a listener to targeted node which sends back the events to client for a queue 
- AddListenerRequest() - Constructor for class com.hazelcast.collection.impl.queue.client.AddListenerRequest
-  
- AddListenerRequest(String, boolean) - Constructor for class com.hazelcast.collection.impl.queue.client.AddListenerRequest
-  
- addLocalEntryListener(MapListener) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- addLocalEntryListener(EntryListener) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- addLocalEntryListener(MapListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- addLocalEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- addLocalEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- addLocalEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- addLocalEntryListener(EntryListener<K, V>) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-  
- addLocalEntryListener(MapListener) - Method in interface com.hazelcast.core.IMap
- 
- addLocalEntryListener(EntryListener) - Method in interface com.hazelcast.core.IMap
- 
- addLocalEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
- 
- addLocalEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
- 
- addLocalEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
- 
Adds a local entry listener for this map. 
- addLocalEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
- 
- addLocalEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.core.MultiMap
- 
Adds a local entry listener for this multimap. 
- addLocalEntryListener(MapListener) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- addLocalEntryListener(EntryListener) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- addLocalEntryListener(MapListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- addLocalEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- addLocalEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- addLocalEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- addLocalEntryListener(EntryListener<K, V>) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-  
- addLocalEventListener(Object, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
-  
- addLocalEventListener(Object, EventFilter, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
-  
- addLocalPartitionLostListener(MapPartitionLostListener, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
-  
- addLocalPartitionLostListener(PartitionLostListener) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- addLocalPartitionLostListener(PartitionLostListener) - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- addLogListener(Level, LogListener) - Method in interface com.hazelcast.logging.LoggingService
-  
- addLogListener(Level, LogListener) - Method in class com.hazelcast.logging.LoggingServiceImpl
-  
- addLongArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addLongField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addMapAttributeConfig(MapAttributeConfig) - Method in class com.hazelcast.config.MapConfig
-  
- addMapConfig(MapConfig) - Method in class com.hazelcast.config.Config
-  
- addMapEntrySet(Object, Object, MapEntries) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- addMapEntrySet(Map<Object, Object>, MapEntries) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- addMapIndex(MapContainer) - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
-  
- addMapIndexConfig(MapIndexConfig) - Method in class com.hazelcast.config.MapConfig
-  
- addMapIndexConfig(MapIndexConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- addMapInterceptors(MapContainer) - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
-  
- addMapPartitionLostListenerConfig(MapPartitionLostListenerConfig) - Method in class com.hazelcast.config.MapConfig
-  
- addMember(String) - Method in class com.hazelcast.config.TcpIpConfig
- 
Adds a 'well known' member. 
- addMember(Member) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
-  
- addMember(Member) - Method in interface com.hazelcast.partition.membergroup.MemberGroup
-  
- addMember(Member) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
-  
- addMemberGroupConfig(MemberGroupConfig) - Method in class com.hazelcast.config.PartitionGroupConfig
- 
- addMemberLoginModuleConfig(LoginModuleConfig) - Method in class com.hazelcast.config.SecurityConfig
-  
- addMembers(Collection<Member>) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
-  
- addMembers(Collection<Member>) - Method in interface com.hazelcast.partition.membergroup.MemberGroup
-  
- addMembers(Collection<Member>) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
-  
- addMembershipListener(MembershipListener) - Method in class com.hazelcast.client.proxy.ClientClusterProxy
-  
- addMembershipListener(MembershipListener) - Method in interface com.hazelcast.client.spi.ClientClusterService
-  
- addMembershipListener(MembershipListener) - Method in class com.hazelcast.client.spi.impl.ClientClusterServiceImpl
-  
- addMembershipListener(MembershipListener) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- addMembershipListener(MembershipListener) - Method in interface com.hazelcast.core.Cluster
- 
Adds MembershipListener to listen for membership updates. 
- AddMembershipListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task
-  
- AddMembershipListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
-  
- AddMembershipListenerRequest - Class in com.hazelcast.cluster.client
-  
- AddMembershipListenerRequest() - Constructor for class com.hazelcast.cluster.client.AddMembershipListenerRequest
-  
- addMessageListener(MessageListener<E>) - Method in class com.hazelcast.client.proxy.ClientReliableTopicProxy
-  
- addMessageListener(MessageListener<E>) - Method in class com.hazelcast.client.proxy.ClientTopicProxy
-  
- addMessageListener(MessageListener<E>) - Method in interface com.hazelcast.core.ITopic
- 
Subscribes to this topic. 
- addMessageListener(MessageListener<E>) - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicProxy
-  
- addMessageListener(MessageListener<E>) - Method in class com.hazelcast.topic.impl.TopicProxy
-  
- addMessageListener(String, MessageListener, boolean) - Method in class com.hazelcast.topic.impl.TopicService
-  
- addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.ReliableTopicConfig
- 
Adds a message listener (listens for when messages are added or removed) to this reliable topic. 
- addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.TopicConfig
- 
Adds a message listener to this topic (listens for when messages are added or removed). 
- addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.TopicConfigReadOnly
-  
- addMessageListenerInternal(MessageListener) - Method in class com.hazelcast.topic.impl.TopicProxySupport
-  
- AddMessageListenerRequest - Class in com.hazelcast.topic.impl.client
-  
- AddMessageListenerRequest() - Constructor for class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-  
- AddMessageListenerRequest(String) - Constructor for class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-  
- addMigrationListener(MigrationListener) - Method in class com.hazelcast.client.proxy.PartitionServiceProxy
-  
- addMigrationListener(MigrationListener) - Method in interface com.hazelcast.core.PartitionService
- 
Adds a MigrationListener. 
- addMigrationListener(MigrationListener) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- addMigrationListener(MigrationListener) - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- addMigrationListener(MigrationListener) - Method in class com.hazelcast.partition.PartitionServiceProxy
-  
- addMulticastListener(MulticastListener) - Method in class com.hazelcast.cluster.impl.MulticastService
-  
- addMultiMapConfig(MultiMapConfig) - Method in class com.hazelcast.config.Config
-  
- addNearCacheConfig(String, NearCacheConfig) - Method in class com.hazelcast.client.config.ClientConfig
- 
Deprecated. 
- addNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.client.config.ClientConfig
- 
Helper method to add a new NearCacheConfig 
- addNearCacheInvalidateListener() - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- addNearCacheInvalidateListener(EventHandler) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- addNearCacheStats(LocalMapStatsImpl, LocalMapStatsProvider.LocalMapOnDemandCalculatedStats, MapContainer) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
- 
Adds near cache stats. 
- addNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-  
- addObject(T) - Method in class com.hazelcast.query.extractor.ValueCollector
- 
Collects a value passed as an argument 
- addObject(Object) - Method in class com.hazelcast.query.impl.DefaultValueCollector
-  
- addOperation(Operation) - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
-  
- AddOperation - Class in com.hazelcast.ringbuffer.impl.operations
-  
- AddOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddOperation
-  
- AddOperation(String, Data, OverflowPolicy) - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddOperation
-  
- addOrGetIndex(String, boolean) - Method in class com.hazelcast.query.impl.Indexes
-  
- addOutboundPort(int) - Method in class com.hazelcast.config.NetworkConfig
-  
- addOutboundPortDefinition(String) - Method in class com.hazelcast.config.NetworkConfig
-  
- addOwnerPartitionStats(LocalMapStatsImpl, LocalMapStatsProvider.LocalMapOnDemandCalculatedStats, String, int) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
- 
Calculates and adds owner partition stats. 
- addOwnershipMapping(String, String) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- addPartitionListener(PartitionListener) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- addPartitionLostListener(CachePartitionLostListener) - Method in interface com.hazelcast.cache.ICache
- 
Adds a CachePartitionLostListener. 
- addPartitionLostListener(CachePartitionLostListener) - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- addPartitionLostListener(CachePartitionLostListener) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- addPartitionLostListener(MapPartitionLostListener) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- addPartitionLostListener(PartitionLostListener) - Method in class com.hazelcast.client.proxy.PartitionServiceProxy
-  
- addPartitionLostListener(MapPartitionLostListener) - Method in interface com.hazelcast.core.IMap
- 
Adds a MapPartitionLostListener. 
- addPartitionLostListener(PartitionLostListener) - Method in interface com.hazelcast.core.PartitionService
- 
Adds a PartitionLostListener. 
- addPartitionLostListener(MapPartitionLostListener, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
-  
- addPartitionLostListener(MapPartitionLostListener) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- addPartitionLostListener(PartitionLostListener) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- addPartitionLostListener(PartitionLostListener) - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- addPartitionLostListener(PartitionLostListener) - Method in class com.hazelcast.partition.PartitionServiceProxy
-  
- AddPartitionLostListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task
-  
- AddPartitionLostListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
-  
- AddPartitionLostListenerRequest - Class in com.hazelcast.partition.client
-  
- AddPartitionLostListenerRequest() - Constructor for class com.hazelcast.partition.client.AddPartitionLostListenerRequest
-  
- addPortableArrayField(String, ClassDefinition) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addPortableFactory(int, PortableFactory) - Method in class com.hazelcast.config.SerializationConfig
-  
- addPortableFactory(int, PortableFactory) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- addPortableFactory(int, PortableFactory) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
-  
- addPortableFactoryClass(int, Class<? extends PortableFactory>) - Method in class com.hazelcast.config.SerializationConfig
-  
- addPortableFactoryClass(int, String) - Method in class com.hazelcast.config.SerializationConfig
-  
- addPortableField(String, ClassDefinition) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addProcessedRecords(int) - Method in class com.hazelcast.mapreduce.impl.task.JobProcessInformationImpl
-  
- addProperty(String, Comparable) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
-  
- addProperty(String, String) - Method in class com.hazelcast.config.ServiceConfig
-  
- addProxyFactoryConfig(ProxyFactoryConfig) - Method in class com.hazelcast.client.config.ClientConfig
- 
- addProxyListener(DistributedObjectListener) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-  
- addProxyListener(DistributedObjectListener) - Method in interface com.hazelcast.spi.ProxyService
-  
- addPutTimeNanos(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
- 
Increments the put time accumulator. 
- addQueryCacheConfig(String, QueryCacheConfig) - Method in class com.hazelcast.client.config.ClientConfig
-  
- addQueryCacheConfig(QueryCacheConfig) - Method in class com.hazelcast.config.MapConfig
- 
Adds a new queryCacheConfigto thisMapConfig.
 
- addQueueConfig(QueueConfig) - Method in class com.hazelcast.config.Config
-  
- addQuorumConfig(QuorumConfig) - Method in class com.hazelcast.config.Config
-  
- addQuorumListener(String, QuorumListener) - Method in class com.hazelcast.quorum.impl.QuorumServiceImpl
-  
- addRegistration(String, Registration) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceSegment
-  
- addReliableTopicConfig(ClientReliableTopicConfig) - Method in class com.hazelcast.client.config.ClientConfig
- 
Adds a ClientReliableTopicConfig. 
- addReliableTopicConfig(ReliableTopicConfig) - Method in class com.hazelcast.config.Config
-  
- addRemoveTimeNanos(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
- 
Increments the remove time accumulator. 
- addReplicaPartitionStats(LocalMapStatsProvider.LocalMapOnDemandCalculatedStats, String, int, InternalPartition, InternalPartitionService, int, Address) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
- 
Calculates and adds replica partition stats. 
- addReplicatedMapConfig(ReplicatedMapConfig) - Method in class com.hazelcast.config.Config
-  
- AddRequest - Class in com.hazelcast.ringbuffer.impl.client
-  
- AddRequest() - Constructor for class com.hazelcast.ringbuffer.impl.client.AddRequest
-  
- AddRequest(String, Data, OverflowPolicy) - Constructor for class com.hazelcast.ringbuffer.impl.client.AddRequest
-  
- ADDRESS - Static variable in class com.hazelcast.cluster.impl.ClusterDataSerializerHook
-  
- address - Variable in class com.hazelcast.cluster.impl.JoinMessage
-  
- address - Variable in class com.hazelcast.instance.AbstractMember
-  
- address - Variable in class com.hazelcast.instance.Node
-  
- address - Variable in class com.hazelcast.internal.management.dto.ClientEndPointDTO
-  
- Address - Class in com.hazelcast.nio
- 
Represents an address of a member in the cluster. 
- Address() - Constructor for class com.hazelcast.nio.Address
-  
- Address(String, int) - Constructor for class com.hazelcast.nio.Address
-  
- Address(InetAddress, int) - Constructor for class com.hazelcast.nio.Address
-  
- Address(InetSocketAddress) - Constructor for class com.hazelcast.nio.Address
- 
Creates a new Address 
- Address(String, InetAddress, int) - Constructor for class com.hazelcast.nio.Address
-  
- Address(Address) - Constructor for class com.hazelcast.nio.Address
-  
- address - Variable in class com.hazelcast.util.AddressUtil.AddressMatcher
-  
- AddressHelper - Class in com.hazelcast.client.util
- 
This is a client side utility class for working with addresses and cluster connections 
- AddressPicker - Interface in com.hazelcast.instance
- 
Strategy to select an  Address that a Hazelcast cluster member binds its server socket to
 and a (potentially different) address that Hazelcast will advertise to other cluster members and clients. 
- AddressProvider - Interface in com.hazelcast.client.connection
- 
Provides initial addresses for client to find and connect to a node 
- AddressTranslator - Interface in com.hazelcast.client.connection
- 
Address Translator is used for resolve private ip
  addresses of cloud services. 
- AddressUtil - Class in com.hazelcast.util
- 
AddressUtil contains Address helper methods 
- AddressUtil.AddressHolder - Class in com.hazelcast.util
- 
Holds address 
- AddressUtil.AddressHolder(String, int, String) - Constructor for class com.hazelcast.util.AddressUtil.AddressHolder
-  
- AddressUtil.AddressMatcher - Class in com.hazelcast.util
- 
http://docs.oracle.com/javase/1.5.0/docs/guide/net/ipv6_guide/index.html 
- AddressUtil.AddressMatcher(String[]) - Constructor for class com.hazelcast.util.AddressUtil.AddressMatcher
-  
- AddressUtil.InvalidAddressException - Exception in com.hazelcast.util
- 
Thrown when given address is not valid. 
- AddressUtil.InvalidAddressException(String) - Constructor for exception com.hazelcast.util.AddressUtil.InvalidAddressException
-  
- addResultSet(ConcurrentMap<Data, QueryableEntry>) - Method in class com.hazelcast.query.impl.DuplicateDetectingMultiResult
-  
- addResultSet(ConcurrentMap<Data, QueryableEntry>) - Method in class com.hazelcast.query.impl.FastMultiResultSet
-  
- addResultSet(ConcurrentMap<Data, QueryableEntry>) - Method in interface com.hazelcast.query.impl.MultiResultSet
- 
TODO 
- addResultsOfPagingPredicate(List<Future<QueryResult>>, Collection, Collection<Integer>) - Method in class com.hazelcast.map.impl.query.MapQueryEngineImpl
- 
Adds results of paging predicates to result set and removes queried partition ids. 
- addResultsOfPredicate(List<Future<QueryResult>>, QueryResult, Collection<Integer>) - Method in class com.hazelcast.map.impl.query.MapQueryEngineImpl
- 
Adds results of non-paging predicates to result set and removes queried partition ids. 
- addRingbuffer(String, RingbufferContainer) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-  
- addRingBufferConfig(RingbufferConfig) - Method in class com.hazelcast.config.Config
-  
- addRow(QueryResultRow) - Method in class com.hazelcast.map.impl.query.QueryResult
-  
- addSecurityInterceptorConfig(SecurityInterceptorConfig) - Method in class com.hazelcast.config.SecurityConfig
-  
- addSemaphoreConfig(SemaphoreConfig) - Method in class com.hazelcast.config.Config
- 
Adds a new SemaphoreConfig by name 
- addSerializerConfig(SerializerConfig) - Method in class com.hazelcast.config.SerializationConfig
-  
- addServiceConfig(ServiceConfig) - Method in class com.hazelcast.config.ServicesConfig
-  
- addSetConfig(SetConfig) - Method in class com.hazelcast.config.Config
-  
- addShortArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addShortField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addStoreListener(StoreListener) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessor
-  
- addTargetClusterConfig(WanTargetClusterConfig) - Method in class com.hazelcast.config.WanReplicationConfig
-  
- addTask(Runnable) - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingIOThread
- 
Adds a task to this NonBlockingIOThread without notifying the thread. 
- addTaskAndWakeup(Runnable) - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingIOThread
- 
Adds a task to be executed by the NonBlockingIOThread and wakes up the selector so that it will
 eventually pick up the task. 
- addTopicConfig(TopicConfig) - Method in class com.hazelcast.config.Config
-  
- addToValueList(Map<K, List<V>>, K, V) - Static method in class com.hazelcast.util.CollectionUtil
- 
Add value to list of values in the map. 
- addTransient(K, long) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
-  
- addTransient(Data, long) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-  
- addTransient(Data, long) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
-  
- addTrustedInterface(String) - Method in class com.hazelcast.config.MulticastConfig
- 
Adds a trusted interface. 
- addUrgent(Object) - Method in class com.hazelcast.spi.impl.operationexecutor.classic.DefaultScheduleQueue
-  
- addUrgent(Object) - Method in interface com.hazelcast.spi.impl.operationexecutor.classic.ScheduleQueue
- 
Adds an task with normal priority to this queue. 
- addUTFArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addUTFField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- addWanReplicationConfig(WanReplicationConfig) - Method in class com.hazelcast.config.Config
-  
- advance() - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-  
- advance() - Method in class com.hazelcast.util.collection.Long2LongHashMap.LongLongCursor
-  
- after(Credentials, String, String, String, Parameters) - Method in interface com.hazelcast.security.SecurityInterceptor
-  
- afterGet(Object) - Method in interface com.hazelcast.map.MapInterceptor
- 
Called after the get(..) operation is completed. 
- afterInsert(Object, Object, Object) - Method in interface com.hazelcast.hibernate.access.AccessDelegate
- 
Called after an item has been inserted (after the transaction completes),
 instead of calling release(). 
- afterInsert(Object, Object, Object) - Method in class com.hazelcast.hibernate.access.NonStrictReadWriteAccessDelegate
- 
Called after an item has been inserted (after the transaction completes),
 instead of calling release(). 
- afterInsert(Object, Object, Object) - Method in class com.hazelcast.hibernate.access.ReadOnlyAccessDelegate
-  
- afterInsert(Object, Object, Object) - Method in class com.hazelcast.hibernate.access.ReadWriteAccessDelegate
-  
- afterInsert(Object, Object, Object) - Method in class com.hazelcast.hibernate.region.EntityRegionAccessStrategyAdapter
-  
- afterInsert(Object, Object) - Method in class com.hazelcast.hibernate.region.NaturalIdRegionAccessStrategyAdapter
-  
- afterInsert(Object, Object, Object) - Method in class com.hazelcast.hibernate.region.NaturalIdRegionAccessStrategyAdapter
-  
- afterPut(Object) - Method in interface com.hazelcast.map.MapInterceptor
- 
Called after the put(..) operation is completed. 
- afterRemove(Object) - Method in interface com.hazelcast.map.MapInterceptor
- 
Called after the remove(..) operation is completed. 
- afterResponse() - Method in class com.hazelcast.client.impl.client.PartitionClientRequest
- 
Called on node side, after sending the response to the client. 
- afterResponse() - Method in class com.hazelcast.client.impl.protocol.task.AbstractPartitionMessageTask
- 
Called on node side, after sending the response to the client. 
- afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
-  
- afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
-  
- afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
-  
- afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
-  
- afterRun() - Method in class com.hazelcast.cache.impl.operation.CachePutBackupOperation
-  
- afterRun() - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
-  
- afterRun() - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
-  
- afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
-  
- afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
-  
- afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
-  
- afterRun() - Method in class com.hazelcast.cluster.impl.operations.JoinCheckOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddBackupOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionClearOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionCompareAndRemoveOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.list.operations.ListSetOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.AddAllOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.ClearOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.ContainsOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.DrainOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.IsEmptyOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.IteratorOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.PeekOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.QueueOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.RemainingCapacityOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.RemoveOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.SizeOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPeekOperation
-  
- afterRun() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollOperation
-  
- afterRun() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
-  
- afterRun() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
-  
- afterRun() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
-  
- afterRun() - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
-  
- afterRun() - Method in class com.hazelcast.internal.management.operation.GetMapConfigOperation
-  
- afterRun() - Method in class com.hazelcast.internal.management.operation.ScriptExecutorOperation
-  
- afterRun() - Method in class com.hazelcast.internal.management.operation.ThreadDumpOperation
-  
- afterRun() - Method in class com.hazelcast.internal.management.operation.UpdateManagementCenterUrlOperation
-  
- afterRun() - Method in class com.hazelcast.internal.management.operation.UpdateMapConfigOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.BasePutOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.ClearExpiredOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.ClearOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.DeleteOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.EntryBackupOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.EntryOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.EvictOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.GetAllOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.GetOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.MapOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.MergeOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.PutIfAbsentOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.RemoveBackupOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.RemoveIfSameOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.RemoveOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.ReplaceOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.SetOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
-  
- afterRun() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-  
- afterRun() - Method in class com.hazelcast.multimap.impl.operations.ClearOperation
-  
- afterRun() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-  
- afterRun() - Method in class com.hazelcast.multimap.impl.operations.PutOperation
-  
- afterRun() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllOperation
-  
- afterRun() - Method in class com.hazelcast.multimap.impl.operations.RemoveOperation
-  
- afterRun() - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
-  
- afterRun() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
-  
- afterRun() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
-  
- afterRun() - Method in class com.hazelcast.partition.impl.CheckReplicaVersion
-  
- afterRun() - Method in class com.hazelcast.partition.impl.IsReplicaVersionSync
-  
- afterRun() - Method in class com.hazelcast.partition.impl.ReplicaSyncRequest
-  
- afterRun() - Method in class com.hazelcast.partition.impl.ReplicaSyncResponse
-  
- afterRun() - Method in class com.hazelcast.partition.impl.ReplicaSyncRetryResponse
-  
- afterRun() - Method in class com.hazelcast.replicatedmap.impl.operation.PutOperation
-  
- afterRun() - Method in class com.hazelcast.replicatedmap.impl.operation.RemoveOperation
-  
- afterRun() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateOperation
-  
- afterRun() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateToCallerOperation
-  
- afterRun() - Method in class com.hazelcast.spi.AbstractOperation
-  
- afterRun() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
-  
- afterRun() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation
-  
- afterRun() - Method in class com.hazelcast.spi.Operation
-  
- afterRun() - Method in class com.hazelcast.util.executor.HazelcastManagedThread
- 
Called after inner run method and can be overridden to customize. 
- afterStart(HazelcastClientInstanceImpl) - Method in interface com.hazelcast.client.ClientExtension
- 
Called after node is started 
- afterStart(HazelcastClientInstanceImpl) - Method in class com.hazelcast.client.impl.DefaultClientExtension
-  
- afterStart() - Method in class com.hazelcast.instance.DefaultNodeExtension
-  
- afterStart() - Method in interface com.hazelcast.instance.NodeExtension
- 
Called after node is started 
- afterUpdate(Object, Object, Object, Object, SoftLock) - Method in interface com.hazelcast.hibernate.access.AccessDelegate
- 
Called after an item has been updated (after the transaction completes),
 instead of calling release(). 
- afterUpdate(Object, Object, Object, Object, SoftLock) - Method in class com.hazelcast.hibernate.access.NonStrictReadWriteAccessDelegate
-  
- afterUpdate(Object, Object, Object, Object, SoftLock) - Method in class com.hazelcast.hibernate.access.ReadOnlyAccessDelegate
-  
- afterUpdate(Object, Object, Object, Object, SoftLock) - Method in class com.hazelcast.hibernate.access.ReadWriteAccessDelegate
- 
Called after an item has been updated (after the transaction completes),
 instead of calling release(). 
- afterUpdate(Object, Object, Object, Object, SoftLock) - Method in class com.hazelcast.hibernate.region.EntityRegionAccessStrategyAdapter
-  
- afterUpdate(Object, Object, SoftLock) - Method in class com.hazelcast.hibernate.region.NaturalIdRegionAccessStrategyAdapter
-  
- afterUpdate(Object, Object, Object, Object, SoftLock) - Method in class com.hazelcast.hibernate.region.NaturalIdRegionAccessStrategyAdapter
-  
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-  
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-  
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in interface com.hazelcast.core.IMap
- 
Executes a predefined aggregation on the maps data set. 
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in interface com.hazelcast.core.IMap
- 
Executes a predefined aggregation on the maps data set. 
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in interface com.hazelcast.core.MultiMap
- 
Executes a predefined aggregation on the multimaps data set. 
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in interface com.hazelcast.core.MultiMap
- 
Executes a predefined aggregation on the multimaps data set. 
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-  
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-  
- Aggregation<Key,Supplied,Result> - Interface in com.hazelcast.mapreduce.aggregation
- 
The Aggregation interface combines multiple map-reduce operations steps to a
 single operation definition. 
- Aggregations - Class in com.hazelcast.mapreduce.aggregation
- 
This class is used to access the Hazelcast predefined set of aggregations in a type-safe
 way. 
- AGGREGATIONS_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- AGGREGATIONS_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- AggregationsDataSerializerHook - Class in com.hazelcast.mapreduce.aggregation.impl
- 
This class contains all the ID hooks for IdentifiedDataSerializable classes used for aggregations. 
- AggregationsDataSerializerHook() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- AggType<KeyIn,ValueIn,KeyOut,SuppliedValue,CombinerValue,ReducerValue,Result> - Interface in com.hazelcast.mapreduce.aggregation.impl
- 
The internal interface for Aggregation definitions to make those implementations more type-safe. 
- alive - Variable in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-  
- all() - Static method in class com.hazelcast.mapreduce.aggregation.Supplier
- 
The predefined Supplier selects all values and does not perform any kind of data
 transformation. 
- all(PropertyExtractor<ValueIn, ValueOut>) - Static method in class com.hazelcast.mapreduce.aggregation.Supplier
- 
The predefined Supplier selects all values and performs the given
  PropertyExtractors transformation to the
 input data. 
- allDone(Collection<Future>) - Static method in class com.hazelcast.util.FutureUtil
- 
Check if all futures are done 
- AllowedDuringPassiveState - Interface in com.hazelcast.spi.impl
- 
Marker interface for operations those are allowed to be executed or invoked during
  Node's  NodeState.PASSIVE state. 
- AllowedDuringPassiveStateTransactionImpl - Class in com.hazelcast.transaction.impl
-  
- AllowedDuringPassiveStateTransactionImpl(TransactionManagerServiceImpl, NodeEngine, TransactionOptions, String) - Constructor for class com.hazelcast.transaction.impl.AllowedDuringPassiveStateTransactionImpl
-  
- allowUnsafe - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- AllPartitionsClientRequest - Class in com.hazelcast.client.impl.client
- 
Base class for client request that will run on all partitions. 
- AllPartitionsClientRequest() - Constructor for class com.hazelcast.client.impl.client.AllPartitionsClientRequest
-  
- AllPermissions - Class in com.hazelcast.security.permission
-  
- AllPermissions() - Constructor for class com.hazelcast.security.permission.AllPermissions
-  
- AllPermissions.AllPermissionsCollection - Class in com.hazelcast.security.permission
-  
- AllPermissions.AllPermissionsCollection() - Constructor for class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
-  
- AllPermissions.AllPermissionsCollection(boolean) - Constructor for class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
-  
- alter(IFunction<Long, Long>) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-  
- alter(IFunction<E, E>) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-  
- ALTER - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-  
- alter(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- ALTER - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-  
- alter(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- alter(IFunction<Long, Long>) - Method in interface com.hazelcast.core.IAtomicLong
- 
Alters the currently stored value by applying a function on it. 
- alter(IFunction<E, E>) - Method in interface com.hazelcast.core.IAtomicReference
- 
Alters the currently stored reference by applying a function on it. 
- ALTER_AND_GET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-  
- ALTER_AND_GET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-  
- alterAndGet(IFunction<Long, Long>) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-  
- alterAndGet(IFunction<E, E>) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-  
- alterAndGet(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- alterAndGet(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- alterAndGet(IFunction<Long, Long>) - Method in interface com.hazelcast.core.IAtomicLong
- 
Alters the currently stored value by applying a function on it and gets the result. 
- alterAndGet(IFunction<E, E>) - Method in interface com.hazelcast.core.IAtomicReference
- 
Alters the currently stored reference by applying a function on it and gets the result. 
- AlterAndGetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-  
- AlterAndGetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AlterAndGetOperation
-  
- AlterAndGetOperation(String, IFunction<Long, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AlterAndGetOperation
-  
- AlterAndGetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-  
- AlterAndGetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AlterAndGetOperation
-  
- AlterAndGetOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AlterAndGetOperation
-  
- AlterAndGetRequest - Class in com.hazelcast.concurrent.atomiclong.client
-  
- AlterAndGetRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.AlterAndGetRequest
-  
- AlterAndGetRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomiclong.client.AlterAndGetRequest
-  
- AlterAndGetRequest - Class in com.hazelcast.concurrent.atomicreference.client
-  
- AlterAndGetRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.AlterAndGetRequest
-  
- AlterAndGetRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.AlterAndGetRequest
-  
- AlterOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-  
- AlterOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AlterOperation
-  
- AlterOperation(String, IFunction<Long, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AlterOperation
-  
- AlterOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-  
- AlterOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AlterOperation
-  
- AlterOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AlterOperation
-  
- AlterRequest - Class in com.hazelcast.concurrent.atomiclong.client
-  
- AlterRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.AlterRequest
-  
- AlterRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomiclong.client.AlterRequest
-  
- AlterRequest - Class in com.hazelcast.concurrent.atomicreference.client
-  
- AlterRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.AlterRequest
-  
- AlterRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.AlterRequest
-  
- and(MemberSelector...) - Static method in class com.hazelcast.cluster.memberselector.MemberSelectors
- 
Selects a member when all of the selectors succeed 
- and(Predicate) - Method in class com.hazelcast.query.PredicateBuilder
-  
- and(Predicate...) - Static method in class com.hazelcast.query.Predicates
-  
- AND_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
-  
- AndPredicate - Class in com.hazelcast.query.impl.predicates
- 
And Predicate 
- AndPredicate() - Constructor for class com.hazelcast.query.impl.predicates.AndPredicate
-  
- AndPredicate(Predicate...) - Constructor for class com.hazelcast.query.impl.predicates.AndPredicate
-  
- AndResultSet - Class in com.hazelcast.query.impl
- 
And Result set for Predicates. 
- AndResultSet(Set<QueryableEntry>, List<Set<QueryableEntry>>, List<Predicate>) - Constructor for class com.hazelcast.query.impl.AndResultSet
-  
- andThen(ExecutionCallback<ClientMessage>) - Method in class com.hazelcast.client.spi.impl.ClientInvocationFuture
-  
- andThen(ExecutionCallback<ClientMessage>, Executor) - Method in class com.hazelcast.client.spi.impl.ClientInvocationFuture
-  
- andThen(ExecutionCallback<V>) - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-  
- andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-  
- andThen(ExecutionCallback<V>) - Method in interface com.hazelcast.core.ICompletableFuture
- 
Registers a callback that will run after the future is completed. 
- andThen(ExecutionCallback<V>, Executor) - Method in interface com.hazelcast.core.ICompletableFuture
- 
Registers a callback that will run with the provided executor after the future is completed. 
- andThen(ExecutionCallback<V>) - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-  
- andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-  
- andThen(ExecutionCallback<V>) - Method in class com.hazelcast.util.executor.CompletedFuture
-  
- andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.util.executor.CompletedFuture
-  
- andThen(ExecutionCallback<V>) - Method in class com.hazelcast.util.executor.DelegatingFuture
-  
- andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.util.executor.DelegatingFuture
-  
- andThenInternal(ExecutionCallback<R>) - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-  
- answerMasterQuestion(JoinMessage, Connection) - Method in class com.hazelcast.cluster.impl.ClusterJoinManager
-  
- ANY_THREAD - Static variable in class com.hazelcast.concurrent.lock.operations.BaseLockOperation
-  
- append(ClientProtocolBuffer, int, int) - Method in class com.hazelcast.client.impl.protocol.util.BufferBuilder
- 
Append a source buffer to the end of the internal buffer, resizing the internal buffer as required. 
- appendToken(StringBuilder, StringBuilder) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-  
- apply(IFunction<Long, R>) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-  
- apply(IFunction<E, R>) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-  
- APPLY - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-  
- apply(IFunction<Long, R>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- APPLY - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-  
- apply(IFunction<E, R>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- apply(IFunction<Long, R>) - Method in interface com.hazelcast.core.IAtomicLong
- 
Applies a function on the value, the actual stored value will not change. 
- apply(IFunction<E, R>) - Method in interface com.hazelcast.core.IAtomicReference
- 
Applies a function on the value, the actual stored value will not change. 
- apply(T) - Method in interface com.hazelcast.core.IFunction
-  
- apply(Map.Entry<KeyIn, ValueIn>) - Method in class com.hazelcast.mapreduce.aggregation.impl.AcceptAllSupplier
-  
- apply(Map.Entry<KeyIn, ValueIn>) - Method in class com.hazelcast.mapreduce.aggregation.impl.KeyPredicateSupplier
-  
- apply(Map.Entry<KeyIn, ValueIn>) - Method in class com.hazelcast.mapreduce.aggregation.impl.PredicateSupplier
-  
- apply(Map.Entry<KeyIn, ValueIn>) - Method in class com.hazelcast.mapreduce.aggregation.Supplier
- 
The apply method is used to apply the actual filtering or extraction / transformation
 to the input entry.
 If the input value should be ignored by the aggregation, the Supplier has to return
 
- apply(Map.Entry) - Method in class com.hazelcast.query.impl.FalsePredicate
-  
- apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
-  
- apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.AndPredicate
-  
- apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.InstanceOfPredicate
-  
- apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.NotEqualPredicate
-  
- apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.NotPredicate
-  
- apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.OrPredicate
-  
- apply(Map.Entry) - Method in class com.hazelcast.query.PagingPredicate
- 
Used for delegating filtering to inner predicate. 
- apply(Map.Entry<K, V>) - Method in interface com.hazelcast.query.Predicate
-  
- apply(Map.Entry) - Method in class com.hazelcast.query.PredicateBuilder
-  
- apply(Map.Entry) - Method in class com.hazelcast.query.SqlPredicate
-  
- apply(Map.Entry) - Method in class com.hazelcast.query.TruePredicate
-  
- apply(Collection<Member>) - Method in interface com.hazelcast.quorum.QuorumFunction
- 
Determines if quorum is present based on the member-list. 
- apply(int) - Method in interface com.hazelcast.util.function.IntFunction
- 
Applies this function to the given argument. 
- apply(long) - Method in interface com.hazelcast.util.function.LongFunction
- 
Applies this function to the given argument. 
- applyChanges() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
- 
Provides a similar functionality as committing a transaction. 
- applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
-  
- applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.BetweenPredicate
-  
- applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.EqualPredicate
-  
- applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
-  
- applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.InPredicate
-  
- applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.LikePredicate
-  
- applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.RegexPredicate
-  
- applyIfAbsent(K, IFunction<? super K, ? extends V>) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
- applyIfAbsent(K, IFunction<? super K, ? extends V>) - Method in interface com.hazelcast.util.IConcurrentMap
- ApplyOperation<R> - Class in com.hazelcast.concurrent.atomiclong.operations
-  
- ApplyOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
-  
- ApplyOperation(String, IFunction<Long, R>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
-  
- ApplyOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-  
- ApplyOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
-  
- ApplyOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
-  
- applyRecordInfo(Record, RecordInfo) - Static method in class com.hazelcast.map.impl.record.Records
-  
- ApplyRequest - Class in com.hazelcast.concurrent.atomiclong.client
-  
- ApplyRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.ApplyRequest
-  
- ApplyRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomiclong.client.ApplyRequest
-  
- ApplyRequest - Class in com.hazelcast.concurrent.atomicreference.client
-  
- ApplyRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.ApplyRequest
-  
- ApplyRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.ApplyRequest
-  
- ArgumentParser<I,O> - Class in com.hazelcast.query.extractor
- 
Common superclass for all argument parsers. 
- ArgumentParser() - Constructor for class com.hazelcast.query.extractor.ArgumentParser
-  
- ARRAY_INDEX_OUT_OF_BOUNDS - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- ARRAY_STORE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- ArrayDataSerializableFactory - Class in com.hazelcast.internal.serialization.impl
-  
- ArrayDataSerializableFactory(ConstructorFunction<Integer, IdentifiedDataSerializable>[]) - Constructor for class com.hazelcast.internal.serialization.impl.ArrayDataSerializableFactory
-  
- ArrayListStreamSerializer - Class in com.hazelcast.internal.serialization.impl
- 
- ArrayListStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ArrayListStreamSerializer
-  
- ArrayUtils - Class in com.hazelcast.util.collection
- 
Convenient method for array manipulations. 
- asCompletableFuture(Future<V>) - Method in interface com.hazelcast.spi.ExecutionService
-  
- asCompletableFuture(Future<V>) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-  
- asElementIterable(NodeList) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
-  
- asList() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
- 
Returns a read-only list representation of this queue. 
- asMap() - Method in class com.hazelcast.hibernate.distributed.IMapRegionCache
-  
- asMap() - Method in class com.hazelcast.hibernate.local.LocalRegionCache
-  
- asMap() - Method in interface com.hazelcast.hibernate.RegionCache
-  
- asMap() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation.PartitionResponse
-  
- asReadOnly() - Method in class com.hazelcast.config.MemberAttributeConfig
-  
- ASSERTION_ERROR - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- assignKeyReducerAddress(Object) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-  
- assignKeyReducerAddress(Object, Address) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-  
- assignMemberId(Address, String, JobTaskConfiguration) - Method in class com.hazelcast.mapreduce.impl.task.MemberAssigningJobProcessInformationImpl
-  
- AssignPartitions - Class in com.hazelcast.partition.impl
-  
- AssignPartitions() - Constructor for class com.hazelcast.partition.impl.AssignPartitions
-  
- associateConnection(Object) - Method in class com.hazelcast.jca.ManagedConnectionImpl
-  
- async - Variable in class com.hazelcast.map.impl.client.MapPutRequest
-  
- async - Variable in class com.hazelcast.map.impl.client.MapRemoveRequest
-  
- ASYNC_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
- 
Name of the async executor. 
- asyncAddAndGet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- asyncAddAndGet(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
- 
Atomically adds the given value to the current value. 
- asyncAlter(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- asyncAlter(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- asyncAlter(IFunction<Long, Long>) - Method in interface com.hazelcast.core.AsyncAtomicLong
- 
Alters the currently stored value by applying a function on it. 
- asyncAlter(IFunction<E, E>) - Method in interface com.hazelcast.core.AsyncAtomicReference
- 
Alters the currently stored reference by applying a function on it. 
- asyncAlterAndGet(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- asyncAlterAndGet(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- asyncAlterAndGet(IFunction<Long, Long>) - Method in interface com.hazelcast.core.AsyncAtomicLong
- 
Alters the currently stored value by applying a function on it and gets the result. 
- asyncAlterAndGet(IFunction<E, E>) - Method in interface com.hazelcast.core.AsyncAtomicReference
- 
Alters the currently stored reference by applying a function on it and gets the result. 
- asyncApply(IFunction<Long, R>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- asyncApply(IFunction<E, R>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- asyncApply(IFunction<Long, R>) - Method in interface com.hazelcast.core.AsyncAtomicLong
- 
Applies a function on the value, the actual stored value will not change. 
- asyncApply(IFunction<E, R>) - Method in interface com.hazelcast.core.AsyncAtomicReference
- 
Applies a function on the value, the actual stored value will not change. 
- AsyncAtomicLong - Interface in com.hazelcast.core
- 
This interface is an  IAtomicLong interface that exposes its operations using an
  ICompletableFuture interface so it can be used in the reactive programming model
 approach. 
- AsyncAtomicReference<E> - Interface in com.hazelcast.core
- 
- asyncClear() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- asyncClear() - Method in interface com.hazelcast.core.AsyncAtomicReference
- 
Clears the current stored reference. 
- asyncCompareAndSet(long, long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- asyncCompareAndSet(E, E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- asyncCompareAndSet(long, long) - Method in interface com.hazelcast.core.AsyncAtomicLong
- 
Atomically sets the value to the given updated value
 only if the current value ==the expected value.
 
- asyncCompareAndSet(E, E) - Method in interface com.hazelcast.core.AsyncAtomicReference
- 
Atomically sets the value to the given updated value
 only if the current value ==the expected value.
 
- AsyncConsoleRequest - Interface in com.hazelcast.internal.management.request
- 
Represents async requests sent from Management Center. 
- asyncContains(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- asyncContains(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
- 
Checks if the reference contains the value. 
- asyncDecrementAndGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- asyncDecrementAndGet() - Method in interface com.hazelcast.core.AsyncAtomicLong
- 
Atomically decrements the current value by one. 
- asyncGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- asyncGet() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- asyncGet() - Method in interface com.hazelcast.core.AsyncAtomicLong
- 
Gets the current value. 
- asyncGet() - Method in interface com.hazelcast.core.AsyncAtomicReference
- 
Gets the current value. 
- asyncGetAndAdd(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- asyncGetAndAdd(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
- 
Atomically adds the given value to the current value. 
- asyncGetAndAlter(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- asyncGetAndAlter(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- asyncGetAndAlter(IFunction<Long, Long>) - Method in interface com.hazelcast.core.AsyncAtomicLong
- 
Alters the currently stored value by applying a function on it on and gets the old value. 
- asyncGetAndAlter(IFunction<E, E>) - Method in interface com.hazelcast.core.AsyncAtomicReference
- 
Alters the currently stored reference by applying a function on it on and gets the old value. 
- asyncGetAndIncrement() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- asyncGetAndIncrement() - Method in interface com.hazelcast.core.AsyncAtomicLong
- 
Atomically increments the current value by one. 
- asyncGetAndSet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- asyncGetAndSet(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- asyncGetAndSet(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
- 
Atomically sets the given value and returns the old value. 
- asyncGetAndSet(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
- 
Gets the value and sets the new value. 
- asyncIncrementAndGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- asyncIncrementAndGet() - Method in interface com.hazelcast.core.AsyncAtomicLong
- 
Atomically increments the current value by one. 
- asyncInvokeOnPartition(String, Operation, int, ExecutionCallback<V>) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- asyncInvokeOnPartition(String, Operation, int, ExecutionCallback<V>) - Method in interface com.hazelcast.spi.impl.operationservice.InternalOperationService
-  
- asyncIsNull() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- asyncIsNull() - Method in interface com.hazelcast.core.AsyncAtomicReference
- 
Checks if the stored reference is null. 
- AsyncResponsePacketHandler - Class in com.hazelcast.spi.impl.operationservice.impl
- 
The AsyncResponsePacketHandler is a PacketHandler that asynchronously process operation-response packets. 
- AsyncResponsePacketHandler(HazelcastThreadGroup, ILogger, PacketHandler) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.AsyncResponsePacketHandler
-  
- asyncSet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- asyncSet(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- asyncSet(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
- 
Atomically sets the given value. 
- asyncSet(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
- 
Atomically sets the given value. 
- asyncSetAndGet(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- asyncSetAndGet(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
- 
Deprecated.
will be removed from Hazelcast 3.4 since it doesn't really serve a purpose. 
 
- ATOMIC_LONG_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- ATOMIC_LONG_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- ATOMIC_LONG_NAME - Static variable in class com.hazelcast.concurrent.idgen.IdGeneratorService
-  
- ATOMIC_LONG_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- ATOMIC_LONG_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- ATOMIC_REFERENCE_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- ATOMIC_REFERENCE_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- ATOMIC_REFERENCE_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- ATOMIC_REFERENCE_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- AtomicLongAddAndGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-  
- AtomicLongAddAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAddAndGetMessageTask
-  
- AtomicLongAlterAndGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-  
- AtomicLongAlterAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterAndGetMessageTask
-  
- AtomicLongAlterMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-  
- AtomicLongAlterMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterMessageTask
-  
- AtomicLongApplyMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-  
- AtomicLongApplyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongApplyMessageTask
-  
- AtomicLongBackupAwareOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-  
- AtomicLongBackupAwareOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
-  
- AtomicLongBackupAwareOperation(String) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
-  
- AtomicLongBaseOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-  
- AtomicLongBaseOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
-  
- AtomicLongBaseOperation(String) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
-  
- AtomicLongCompareAndSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-  
- AtomicLongCompareAndSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongCompareAndSetMessageTask
-  
- AtomicLongContainer - Class in com.hazelcast.concurrent.atomiclong
-  
- AtomicLongContainer() - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
-  
- AtomicLongDataSerializerHook - Class in com.hazelcast.concurrent.atomiclong
-  
- AtomicLongDataSerializerHook() - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-  
- AtomicLongDecrementAndGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-  
- AtomicLongDecrementAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongDecrementAndGetMessageTask
-  
- AtomicLongGetAndAddMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-  
- AtomicLongGetAndAddMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAddMessageTask
-  
- AtomicLongGetAndAlterMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-  
- AtomicLongGetAndAlterMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAlterMessageTask
-  
- AtomicLongGetAndIncrementMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-  
- AtomicLongGetAndIncrementMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndIncrementMessageTask
-  
- AtomicLongGetAndSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-  
- AtomicLongGetAndSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndSetMessageTask
-  
- AtomicLongGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-  
- AtomicLongGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetMessageTask
-  
- AtomicLongIncrementAndGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-  
- AtomicLongIncrementAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongIncrementAndGetMessageTask
-  
- AtomicLongMBean - Class in com.hazelcast.jmx
- 
- AtomicLongMBean(IAtomicLong, ManagementService) - Constructor for class com.hazelcast.jmx.AtomicLongMBean
-  
- AtomicLongPermission - Class in com.hazelcast.security.permission
-  
- AtomicLongPermission(String, String...) - Constructor for class com.hazelcast.security.permission.AtomicLongPermission
-  
- AtomicLongPortableHook - Class in com.hazelcast.concurrent.atomiclong.client
-  
- AtomicLongPortableHook() - Constructor for class com.hazelcast.concurrent.atomiclong.client.AtomicLongPortableHook
-  
- AtomicLongProxy - Class in com.hazelcast.concurrent.atomiclong
-  
- AtomicLongProxy(String, NodeEngine, AtomicLongService) - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- AtomicLongReplicationOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-  
- AtomicLongReplicationOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
-  
- AtomicLongReplicationOperation(Map<String, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
-  
- AtomicLongRequest - Class in com.hazelcast.concurrent.atomiclong.client
-  
- AtomicLongRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
-  
- AtomicLongRequest(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
-  
- AtomicLongService - Class in com.hazelcast.concurrent.atomiclong
-  
- AtomicLongService() - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongService
-  
- AtomicLongSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-  
- AtomicLongSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongSetMessageTask
-  
- AtomicReferenceAlterAndGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-  
- AtomicReferenceAlterAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterAndGetMessageTask
-  
- AtomicReferenceAlterMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-  
- AtomicReferenceAlterMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterMessageTask
-  
- AtomicReferenceApplyMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-  
- AtomicReferenceApplyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceApplyMessageTask
-  
- AtomicReferenceBackupAwareOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-  
- AtomicReferenceBackupAwareOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
-  
- AtomicReferenceBackupAwareOperation(String) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
-  
- AtomicReferenceBaseOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-  
- AtomicReferenceBaseOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
-  
- AtomicReferenceBaseOperation(String) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
-  
- AtomicReferenceClearMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-  
- AtomicReferenceClearMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceClearMessageTask
-  
- AtomicReferenceCompareAndSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-  
- AtomicReferenceCompareAndSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceCompareAndSetMessageTask
-  
- AtomicReferenceContainer - Class in com.hazelcast.concurrent.atomicreference
-  
- AtomicReferenceContainer() - Constructor for class com.hazelcast.concurrent.atomicreference.AtomicReferenceContainer
-  
- AtomicReferenceContainsMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-  
- AtomicReferenceContainsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceContainsMessageTask
-  
- AtomicReferenceDataSerializerHook - Class in com.hazelcast.concurrent.atomicreference
-  
- AtomicReferenceDataSerializerHook() - Constructor for class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-  
- AtomicReferenceGetAndAlterMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-  
- AtomicReferenceGetAndAlterMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndAlterMessageTask
-  
- AtomicReferenceGetAndSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-  
- AtomicReferenceGetAndSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndSetMessageTask
-  
- AtomicReferenceGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-  
- AtomicReferenceGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetMessageTask
-  
- AtomicReferenceIsNullMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-  
- AtomicReferenceIsNullMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceIsNullMessageTask
-  
- AtomicReferenceMBean - Class in com.hazelcast.jmx
- 
- AtomicReferenceMBean(IAtomicReference, ManagementService) - Constructor for class com.hazelcast.jmx.AtomicReferenceMBean
-  
- AtomicReferencePermission - Class in com.hazelcast.security.permission
-  
- AtomicReferencePermission(String, String...) - Constructor for class com.hazelcast.security.permission.AtomicReferencePermission
-  
- AtomicReferencePortableHook - Class in com.hazelcast.concurrent.atomicreference.client
-  
- AtomicReferencePortableHook() - Constructor for class com.hazelcast.concurrent.atomicreference.client.AtomicReferencePortableHook
-  
- AtomicReferenceProxy<E> - Class in com.hazelcast.concurrent.atomicreference
-  
- AtomicReferenceProxy(String, NodeEngine, AtomicReferenceService) - Constructor for class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- AtomicReferenceReplicationOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-  
- AtomicReferenceReplicationOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
-  
- AtomicReferenceReplicationOperation(Map<String, Data>) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
-  
- AtomicReferenceService - Class in com.hazelcast.concurrent.atomicreference
-  
- AtomicReferenceService() - Constructor for class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-  
- AtomicReferenceSetAndGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-  
- AtomicReferenceSetAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetAndGetMessageTask
-  
- AtomicReferenceSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-  
- AtomicReferenceSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetMessageTask
-  
- attributeMap - Variable in class com.hazelcast.jmx.HazelcastMBean
-  
- attributes - Variable in class com.hazelcast.instance.AbstractMember
-  
- AttributeType - Enum in com.hazelcast.query.impl
- 
Type of Attribute 
- AUTH - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-  
- authenticate(ClientConnection) - Method in interface com.hazelcast.client.connection.Authenticator
- 
Authenticates a ClientConnection. 
- authenticate(ClientConnection) - Method in class com.hazelcast.client.impl.ClusterAuthenticator
-  
- authenticated(ClientPrincipal, Credentials, boolean) - Method in interface com.hazelcast.client.ClientEndpoint
-  
- authenticated(ClientPrincipal) - Method in interface com.hazelcast.client.ClientEndpoint
-  
- authenticated(ClientPrincipal, Credentials, boolean) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- authenticated(ClientPrincipal) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- AUTHENTICATION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- AUTHENTICATION - Static variable in class com.hazelcast.client.impl.protocol.ResponseMessageConst
-  
- AuthenticationBaseMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
- 
Base authentication task 
- AuthenticationBaseMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
-  
- AuthenticationCustomCredentialsMessageTask - Class in com.hazelcast.client.impl.protocol.task
- 
Custom Authentication with custom credential impl 
- AuthenticationCustomCredentialsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AuthenticationCustomCredentialsMessageTask
-  
- AuthenticationException - Exception in com.hazelcast.client
- 
- AuthenticationException() - Constructor for exception com.hazelcast.client.AuthenticationException
- 
Creates a AuthenticationException with a default message. 
- AuthenticationException(String) - Constructor for exception com.hazelcast.client.AuthenticationException
- 
Creates a AuthenticationException with the given message. 
- AuthenticationFailureOperation - Class in com.hazelcast.cluster.impl.operations
-  
- AuthenticationFailureOperation() - Constructor for class com.hazelcast.cluster.impl.operations.AuthenticationFailureOperation
-  
- AuthenticationMessageTask - Class in com.hazelcast.client.impl.protocol.task
- 
Default Authentication with username password handling task 
- AuthenticationMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AuthenticationMessageTask
-  
- AuthenticationRequest - Class in com.hazelcast.client.impl.client
- 
Client Authentication Request that holds credentials 
- AuthenticationRequest() - Constructor for class com.hazelcast.client.impl.client.AuthenticationRequest
-  
- AuthenticationRequest(Credentials) - Constructor for class com.hazelcast.client.impl.client.AuthenticationRequest
-  
- AuthenticationRequest(Credentials, ClientPrincipal) - Constructor for class com.hazelcast.client.impl.client.AuthenticationRequest
-  
- AuthenticationStatus - Enum in com.hazelcast.client.impl.protocol
- 
Status codes of authentication results 
- Authenticator - Interface in com.hazelcast.client.connection
- 
- AuthorizationOperation - Class in com.hazelcast.cluster.impl.operations
-  
- AuthorizationOperation() - Constructor for class com.hazelcast.cluster.impl.operations.AuthorizationOperation
-  
- AuthorizationOperation(String, String) - Constructor for class com.hazelcast.cluster.impl.operations.AuthorizationOperation
-  
- available() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- AVAILABLE_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-  
- AvailableOperation - Class in com.hazelcast.concurrent.semaphore.operations
-  
- AvailableOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.AvailableOperation
-  
- AvailableOperation(String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.AvailableOperation
-  
- availablePermits() - Method in class com.hazelcast.client.proxy.ClientSemaphoreProxy
-  
- availablePermits() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-  
- availablePermits() - Method in interface com.hazelcast.core.ISemaphore
- 
Returns the current number of permits currently available in this semaphore. 
- AvailableRequest - Class in com.hazelcast.concurrent.semaphore.client
-  
- AvailableRequest() - Constructor for class com.hazelcast.concurrent.semaphore.client.AvailableRequest
-  
- AvailableRequest(String) - Constructor for class com.hazelcast.concurrent.semaphore.client.AvailableRequest
-  
- AVG_TUPLE - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- AvgTuple<F,S> - Class in com.hazelcast.mapreduce.aggregation.impl
- 
Internal tuple type for average calculations, used to transmit data between
 Combiner and Reducer implementations. 
- AvgTuple(F, S) - Constructor for class com.hazelcast.mapreduce.aggregation.impl.AvgTuple
-  
- await() - Method in class com.hazelcast.client.proxy.ClientConditionProxy
-  
- await(long, TimeUnit) - Method in class com.hazelcast.client.proxy.ClientConditionProxy
-  
- await(long, TimeUnit) - Method in class com.hazelcast.client.proxy.ClientCountDownLatchProxy
-  
- await(long, TimeUnit) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
-  
- AWAIT - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
-  
- await(long, TimeUnit) - Method in interface com.hazelcast.core.ICountDownLatch
- 
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. 
- await(WaitSupport) - Method in class com.hazelcast.spi.impl.waitnotifyservice.impl.WaitNotifyServiceImpl
-  
- await(WaitSupport) - Method in interface com.hazelcast.spi.WaitNotifyService
- 
- AWAIT_BACKUP - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
-  
- AWAIT_COMPLETION_TIMEOUT_SECONDS - Static variable in class com.hazelcast.cache.impl.CacheProxyUtil
-  
- AWAIT_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-  
- AwaitBackupOperation - Class in com.hazelcast.concurrent.lock.operations
-  
- AwaitBackupOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitBackupOperation
-  
- AwaitBackupOperation(ObjectNamespace, Data, long, String, String) - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitBackupOperation
-  
- awaitNanos(long) - Method in class com.hazelcast.client.proxy.ClientConditionProxy
-  
- AwaitOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
-  
- AwaitOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
-  
- AwaitOperation(String, long) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
-  
- AwaitOperation - Class in com.hazelcast.concurrent.lock.operations
-  
- AwaitOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitOperation
-  
- AwaitOperation(ObjectNamespace, Data, long, long, String) - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitOperation
-  
- AwaitRequest - Class in com.hazelcast.concurrent.countdownlatch.client
-  
- AwaitRequest() - Constructor for class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-  
- AwaitRequest(String, long) - Constructor for class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-  
- AwaitRequest - Class in com.hazelcast.concurrent.lock.client
-  
- AwaitRequest() - Constructor for class com.hazelcast.concurrent.lock.client.AwaitRequest
-  
- AwaitRequest(ObjectNamespace, String, long, long, String) - Constructor for class com.hazelcast.concurrent.lock.client.AwaitRequest
-  
- awaitTermination(long, TimeUnit) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- awaitTermination(long, TimeUnit) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- awaitTermination(int, TimeUnit) - Method in class com.hazelcast.spi.impl.operationexecutor.classic.OperationThread
-  
- awaitTermination(long) - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationMonitor
-  
- awaitTermination(long, TimeUnit) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-  
- awaitUninterruptibly() - Method in class com.hazelcast.client.proxy.ClientConditionProxy
-  
- awaitUntil(Date) - Method in class com.hazelcast.client.proxy.ClientConditionProxy
-  
- AwsAddressProvider - Class in com.hazelcast.client.spi.impl
- 
Aws Address Loader. 
- AwsAddressProvider(ClientAwsConfig) - Constructor for class com.hazelcast.client.spi.impl.AwsAddressProvider
-  
- AwsAddressTranslator - Class in com.hazelcast.client.spi.impl
- 
AwsLookupTable loads ec2 ip addresses with given aws credentials. 
- AwsAddressTranslator(ClientAwsConfig) - Constructor for class com.hazelcast.client.spi.impl.AwsAddressTranslator
-  
- AWSClient - Class in com.hazelcast.aws
-  
- AWSClient(AwsConfig) - Constructor for class com.hazelcast.aws.AWSClient
-  
- AwsConfig - Class in com.hazelcast.config
- 
The AWSConfig contains the configuration for AWS join mechanism. 
- AwsConfig() - Constructor for class com.hazelcast.config.AwsConfig
-  
- AwsURLEncoder - Class in com.hazelcast.aws.utility
-  
- cache - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-  
- CACHE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- cache - Variable in class com.hazelcast.hibernate.access.AbstractAccessDelegate
-  
- cache - Variable in class com.hazelcast.hibernate.local.LocalRegionCache
-  
- CACHE_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- CACHE_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- CACHE_EVENT_DATA - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- CACHE_EVENT_DATA_SET - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- CACHE_KEY_ITERATOR_RESULT - Static variable in class com.hazelcast.client.impl.protocol.ResponseMessageConst
-  
- CACHE_LINE_LENGTH - Static variable in class com.hazelcast.nio.Bits
- 
Length of the data blocks used by the CPU cache sub-system in bytes. 
- CACHE_LOADER - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- CACHE_NOT_EXISTS - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- CACHE_PARTITION_LOST_EVENT - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
-  
- CACHE_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- CACHE_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- CACHE_WRITER - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- CacheAddEntryListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
Client request which registers an event listener on behalf of the client and delegates the received events
 back to client. 
- CacheAddEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheAddEntryListenerMessageTask
-  
- CacheAddEntryListenerRequest - Class in com.hazelcast.cache.impl.client
- 
Client request which registers an event listener on behalf of the client and delegates the received events
 back to client. 
- CacheAddEntryListenerRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
-  
- CacheAddEntryListenerRequest(String) - Constructor for class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
-  
- CacheAddInvalidationListenerRequest - Class in com.hazelcast.cache.impl.client
-  
- CacheAddInvalidationListenerRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheAddInvalidationListenerRequest
-  
- CacheAddInvalidationListenerRequest(String) - Constructor for class com.hazelcast.cache.impl.client.CacheAddInvalidationListenerRequest
-  
- CacheAddInvalidationListenerTask - Class in com.hazelcast.client.impl.protocol.task.cache
-  
- CacheAddInvalidationListenerTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheAddInvalidationListenerTask
-  
- CacheAddPartitionLostListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-  
- CacheAddPartitionLostListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
-  
- CacheAddPartitionLostListenerRequest - Class in com.hazelcast.cache.impl.client
-  
- CacheAddPartitionLostListenerRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheAddPartitionLostListenerRequest
-  
- CacheAddPartitionLostListenerRequest(String) - Constructor for class com.hazelcast.cache.impl.client.CacheAddPartitionLostListenerRequest
-  
- CacheBackupEntryProcessorOperation - Class in com.hazelcast.cache.impl.operation
- 
Operation of the Cache Backup Entry Processor. 
- CacheBackupEntryProcessorOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
-  
- CacheBackupEntryProcessorOperation(String, Data, EntryProcessor, Object...) - Constructor for class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
-  
- CacheBatchInvalidationMessage - Class in com.hazelcast.cache.impl.client
-  
- CacheBatchInvalidationMessage() - Constructor for class com.hazelcast.cache.impl.client.CacheBatchInvalidationMessage
-  
- CacheBatchInvalidationMessage(String) - Constructor for class com.hazelcast.cache.impl.client.CacheBatchInvalidationMessage
-  
- CacheBatchInvalidationMessage(String, int) - Constructor for class com.hazelcast.cache.impl.client.CacheBatchInvalidationMessage
-  
- CacheBatchInvalidationMessage(String, List<CacheSingleInvalidationMessage>) - Constructor for class com.hazelcast.cache.impl.client.CacheBatchInvalidationMessage
-  
- CacheClearBackupOperation - Class in com.hazelcast.cache.impl.operation
- 
- CacheClearBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
-  
- CacheClearBackupOperation(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
-  
- CacheClearMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CacheClearMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
-  
- CacheClearOperation - Class in com.hazelcast.cache.impl.operation
- 
Cache Clear will clear all internal cache data without sending any event 
- CacheClearOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheClearOperation
-  
- CacheClearOperation(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheClearOperation
-  
- CacheClearOperationFactory - Class in com.hazelcast.cache.impl.operation
- 
- CacheClearOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
-  
- CacheClearOperationFactory(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
-  
- CacheClearRequest - Class in com.hazelcast.cache.impl.client
- 
- CacheClearRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheClearRequest
-  
- CacheClearRequest(String, Set<Data>, boolean, int) - Constructor for class com.hazelcast.cache.impl.client.CacheClearRequest
-  
- CacheClearResponse - Class in com.hazelcast.cache.impl
- 
- CacheClearResponse() - Constructor for class com.hazelcast.cache.impl.CacheClearResponse
-  
- CacheClearResponse(Object) - Constructor for class com.hazelcast.cache.impl.CacheClearResponse
-  
- cacheConfig - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- CacheConfig<K,V> - Class in com.hazelcast.config
- 
Contains all the configuration for the  ICache. 
- CacheConfig() - Constructor for class com.hazelcast.config.CacheConfig
-  
- CacheConfig(String) - Constructor for class com.hazelcast.config.CacheConfig
-  
- CacheConfig(CompleteConfiguration<K, V>) - Constructor for class com.hazelcast.config.CacheConfig
-  
- CacheConfig(CacheSimpleConfig) - Constructor for class com.hazelcast.config.CacheConfig
-  
- CacheConfigReadOnly<K,V> - Class in com.hazelcast.config
- 
- CacheConfiguration<K,V> - Interface in com.hazelcast.config
- 
Mutable extension to CompleteConfiguration
 
- CacheContainsKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CacheContainsKeyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheContainsKeyMessageTask
-  
- CacheContainsKeyOperation - Class in com.hazelcast.cache.impl.operation
- 
Cache contains key operation, determines if the cache contains an entry for the specified key. 
- CacheContainsKeyOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheContainsKeyOperation
-  
- CacheContainsKeyOperation(String, Data) - Constructor for class com.hazelcast.cache.impl.operation.CacheContainsKeyOperation
-  
- CacheContainsKeyRequest - Class in com.hazelcast.cache.impl.client
- 
- CacheContainsKeyRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheContainsKeyRequest
-  
- CacheContainsKeyRequest(String, Data, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheContainsKeyRequest
-  
- cacheContexesConstructorFunction - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-  
- cacheContext - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- CacheContext - Class in com.hazelcast.cache.impl
- 
Holds some specific informations for per cache in the node and shared by all partitions of that cache on the node. 
- CacheContext() - Constructor for class com.hazelcast.cache.impl.CacheContext
-  
- cacheContexts - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-  
- CacheCreateConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CacheCreateConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheCreateConfigMessageTask
-  
- CacheCreateConfigOperation - Class in com.hazelcast.cache.impl.operation
- 
Used to create cluster wide cache configuration. 
- CacheCreateConfigOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-  
- CacheCreateConfigOperation(CacheConfig) - Constructor for class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-  
- CacheCreateConfigOperation(CacheConfig, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-  
- CacheCreateConfigOperation(CacheConfig, boolean, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-  
- CacheCreateConfigRequest - Class in com.hazelcast.cache.impl.client
- 
- CacheCreateConfigRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheCreateConfigRequest
-  
- CacheCreateConfigRequest(CacheConfig, boolean, boolean, int) - Constructor for class com.hazelcast.cache.impl.client.CacheCreateConfigRequest
-  
- CacheDataRecord - Class in com.hazelcast.cache.impl.record
- 
Implementation of  CacheRecord where value has an internal serialized format. 
- CacheDataRecord() - Constructor for class com.hazelcast.cache.impl.record.CacheDataRecord
-  
- CacheDataRecord(Data, long, long) - Constructor for class com.hazelcast.cache.impl.record.CacheDataRecord
-  
- CacheDataSerializerHook - Class in com.hazelcast.cache.impl
- 
- CacheDataSerializerHook() - Constructor for class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- CacheDeserializedValues - Enum in com.hazelcast.config
- 
Control caching of de-serialized values. 
- CacheDestroyMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-  
- CacheDestroyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
-  
- CacheDestroyOperation - Class in com.hazelcast.cache.impl.operation
- 
Destroys the cache on the cluster or on a single node by calling
 CacheService#deleteCache(String, boolean, String, boolean).
 
- CacheDestroyOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheDestroyOperation
-  
- CacheDestroyOperation(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheDestroyOperation
-  
- CacheDestroyOperation(String, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheDestroyOperation
-  
- CacheDestroyRequest - Class in com.hazelcast.cache.impl.client
- 
- CacheDestroyRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheDestroyRequest
-  
- CacheDestroyRequest(String, int) - Constructor for class com.hazelcast.cache.impl.client.CacheDestroyRequest
-  
- CachedExecutorServiceDelegate - Class in com.hazelcast.util.executor
-  
- CachedExecutorServiceDelegate(NodeEngine, String, ExecutorService, int, int) - Constructor for class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-  
- CacheDistributedObject - Class in com.hazelcast.cache.impl
- 
- CacheDistributedObject(String, NodeEngine, ICacheService) - Constructor for class com.hazelcast.cache.impl.CacheDistributedObject
-  
- CachedQueryEntry - Class in com.hazelcast.query.impl
- 
Entry of the Query. 
- CachedQueryEntry() - Constructor for class com.hazelcast.query.impl.CachedQueryEntry
-  
- CachedQueryEntry(SerializationService, Data, Object, Extractors) - Constructor for class com.hazelcast.query.impl.CachedQueryEntry
-  
- CacheEntry<K,V> - Class in com.hazelcast.cache.impl
- 
Simple  Cache.Entryimplementation for wrapping a "key,value" pair.
 
- CacheEntry(K, V) - Constructor for class com.hazelcast.cache.impl.CacheEntry
-  
- CacheEntryCountResolver - Class in com.hazelcast.cache.impl
- 
Contract point for tracking count of stored cache entries. 
- CacheEntryCountResolver() - Constructor for class com.hazelcast.cache.impl.CacheEntryCountResolver
-  
- cacheEntryCountResolver - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- CacheEntryEventImpl<K,V> - Class in com.hazelcast.cache.impl
- 
CacheEntryEvent implementation is the actual event object received by sub-interfaces of
 CacheEntryListener.
 
- CacheEntryEventImpl(ICache<K, V>, EventType, K, V, V) - Constructor for class com.hazelcast.cache.impl.CacheEntryEventImpl
-  
- cacheEntryListenerDeregistered(String, CacheEntryListenerConfiguration) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- CacheEntryListenerProvider<K,V> - Interface in com.hazelcast.cache.impl
- 
Provides underlying (wrapped) CacheEntryListenerinstance.
 
- cacheEntryListenerRegistered(String, CacheEntryListenerConfiguration) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- CacheEntryProcessorEntry<K,V,R extends CacheRecord> - Class in com.hazelcast.cache.impl
- 
This class is an implementation of MutableEntrywhich is provided intoEntryProcessor.process(javax.cache.processor.MutableEntry, Object...).
 
- CacheEntryProcessorEntry(Data, R, AbstractCacheRecordStore, long, int) - Constructor for class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-  
- CacheEntryProcessorEntry.State - Enum in com.hazelcast.cache.impl
-  
- CacheEntryProcessorMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CacheEntryProcessorMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheEntryProcessorMessageTask
-  
- CacheEntryProcessorOperation - Class in com.hazelcast.cache.impl.operation
- 
Operation of the Cache Entry Processor. 
- CacheEntryProcessorOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
-  
- CacheEntryProcessorOperation(String, Data, int, EntryProcessor, Object...) - Constructor for class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
-  
- CacheEntryProcessorRequest - Class in com.hazelcast.cache.impl.client
- 
- CacheEntryProcessorRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheEntryProcessorRequest
-  
- CacheEntryProcessorRequest(String, Data, EntryProcessor, InMemoryFormat, Object...) - Constructor for class com.hazelcast.cache.impl.client.CacheEntryProcessorRequest
-  
- CacheEntryProcessorResult<T> - Class in com.hazelcast.cache.impl
- 
This simple implementation of EntryProcessorResultwraps the result returned or exception thrown in a
 single object so that multiple exceptions from multiple entry processes can be returned.
 
- CacheEntryProcessorResult(T) - Constructor for class com.hazelcast.cache.impl.CacheEntryProcessorResult
-  
- CacheEntryProcessorResult(Throwable) - Constructor for class com.hazelcast.cache.impl.CacheEntryProcessorResult
-  
- CacheEntryView<K,V> - Interface in com.hazelcast.cache
- 
Entry info for cache record. 
- CacheEntryViews - Class in com.hazelcast.cache.impl
- 
A class providing static factory methods that create various entry view objects. 
- CacheEntryViews.CacheEntryViewType - Enum in com.hazelcast.cache.impl
- 
- CacheEnvironment - Class in com.hazelcast.hibernate
- 
This class is used to help in setup the internal caches. 
- CacheEventContext - Class in com.hazelcast.cache.impl
- 
- CacheEventContext() - Constructor for class com.hazelcast.cache.impl.CacheEventContext
-  
- CacheEventContextUtil - Class in com.hazelcast.cache.impl
- 
- CacheEventData - Interface in com.hazelcast.cache.impl
- 
Internal event data wrapper used during publishing and dispatching events. 
- CacheEventDataImpl - Class in com.hazelcast.cache.impl
- 
- CacheEventDataImpl() - Constructor for class com.hazelcast.cache.impl.CacheEventDataImpl
-  
- CacheEventDataImpl(String, CacheEventType, Data, Data, Data, boolean) - Constructor for class com.hazelcast.cache.impl.CacheEventDataImpl
-  
- cacheEventHandler - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-  
- CacheEventListener - Interface in com.hazelcast.cache.impl
- 
Cache Event Listener interface is designated for handling cache events internally such as delegating events
 to cache event listener. 
- CacheEventListenerAdaptor<K,V> - Class in com.hazelcast.cache.impl
- 
This implementation of  CacheEventListener uses the adapter pattern for wrapping all cache event listener
 types into a single listener. 
- CacheEventListenerAdaptor(ICache<K, V>, CacheEntryListenerConfiguration<K, V>, SerializationService) - Constructor for class com.hazelcast.cache.impl.CacheEventListenerAdaptor
-  
- CacheEventSet - Class in com.hazelcast.cache.impl
- 
Internal Set wrapper of  CacheEventData items used during publishing and dispatching events. 
- CacheEventSet() - Constructor for class com.hazelcast.cache.impl.CacheEventSet
-  
- CacheEventSet(CacheEventType, Set<CacheEventData>) - Constructor for class com.hazelcast.cache.impl.CacheEventSet
-  
- CacheEventSet(CacheEventType, Set<CacheEventData>, int) - Constructor for class com.hazelcast.cache.impl.CacheEventSet
-  
- CacheEventSet(CacheEventType, int) - Constructor for class com.hazelcast.cache.impl.CacheEventSet
-  
- CacheEventType - Enum in com.hazelcast.cache.impl
- 
Hazelcast JCache implementation's internal event types. 
- CacheEvictionConfig - Class in com.hazelcast.config
- 
- CacheEvictionConfig() - Constructor for class com.hazelcast.config.CacheEvictionConfig
- 
Deprecated. 
- CacheEvictionConfig(int, EvictionConfig.MaxSizePolicy, EvictionPolicy) - Constructor for class com.hazelcast.config.CacheEvictionConfig
- 
Deprecated. 
- CacheEvictionConfig(int, CacheEvictionConfig.CacheMaxSizePolicy, EvictionPolicy) - Constructor for class com.hazelcast.config.CacheEvictionConfig
- 
Deprecated. 
- CacheEvictionConfig(EvictionConfig) - Constructor for class com.hazelcast.config.CacheEvictionConfig
- 
Deprecated. 
- CacheEvictionConfig.CacheMaxSizePolicy - Enum in com.hazelcast.config
- 
Deprecated. Cache Maximum Size Policy 
- CacheEvictionConfigReadOnly - Class in com.hazelcast.config
- 
- CacheEvictionConfigReadOnly(EvictionConfig) - Constructor for class com.hazelcast.config.CacheEvictionConfigReadOnly
- 
Deprecated. 
- CacheGetAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CacheGetAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheGetAllMessageTask
-  
- CacheGetAllOperation - Class in com.hazelcast.cache.impl.operation
- 
Gets all keys from the cache. 
- CacheGetAllOperation(String, Set<Data>, ExpiryPolicy) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAllOperation
-  
- CacheGetAllOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAllOperation
-  
- CacheGetAllOperationFactory - Class in com.hazelcast.cache.impl.operation
- 
- CacheGetAllOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
-  
- CacheGetAllOperationFactory(String, Set<Data>, ExpiryPolicy) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
-  
- CacheGetAllRequest - Class in com.hazelcast.cache.impl.client
- 
- CacheGetAllRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheGetAllRequest
-  
- CacheGetAllRequest(String, Set<Data>, ExpiryPolicy) - Constructor for class com.hazelcast.cache.impl.client.CacheGetAllRequest
-  
- CacheGetAndRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CacheGetAndRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndRemoveMessageTask
-  
- CacheGetAndRemoveOperation - Class in com.hazelcast.cache.impl.operation
- 
Cache GetAndRemove Operation. 
- CacheGetAndRemoveOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
-  
- CacheGetAndRemoveOperation(String, Data, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
-  
- CacheGetAndRemoveRequest - Class in com.hazelcast.cache.impl.client
- 
- CacheGetAndRemoveRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheGetAndRemoveRequest
-  
- CacheGetAndRemoveRequest(String, Data, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheGetAndRemoveRequest
-  
- CacheGetAndReplaceMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CacheGetAndReplaceMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndReplaceMessageTask
-  
- CacheGetAndReplaceOperation - Class in com.hazelcast.cache.impl.operation
- 
Cache GetAndReplace Operation. 
- CacheGetAndReplaceOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
-  
- CacheGetAndReplaceOperation(String, Data, Data, ExpiryPolicy, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
-  
- CacheGetAndReplaceRequest - Class in com.hazelcast.cache.impl.client
- 
- CacheGetAndReplaceRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheGetAndReplaceRequest
-  
- CacheGetAndReplaceRequest(String, Data, Data, ExpiryPolicy, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheGetAndReplaceRequest
-  
- CacheGetConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CacheGetConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheGetConfigMessageTask
-  
- CacheGetConfigOperation - Class in com.hazelcast.cache.impl.operation
- 
Cache GetConfig Operation. 
- CacheGetConfigOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
-  
- CacheGetConfigOperation(String, String) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
-  
- CacheGetConfigRequest - Class in com.hazelcast.cache.impl.client
- 
- CacheGetConfigRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheGetConfigRequest
-  
- CacheGetConfigRequest(String, String, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheGetConfigRequest
-  
- CacheGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CacheGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheGetMessageTask
-  
- CacheGetOperation - Class in com.hazelcast.cache.impl.operation
- 
Cache Get Operation. 
- CacheGetOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetOperation
-  
- CacheGetOperation(String, Data, ExpiryPolicy) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetOperation
-  
- CacheGetRequest - Class in com.hazelcast.cache.impl.client
- 
- CacheGetRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheGetRequest
-  
- CacheGetRequest(String, Data, ExpiryPolicy, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheGetRequest
-  
- CacheInvalidationListener - Class in com.hazelcast.cache.impl.client
-  
- CacheInvalidationListener(ClientEndpoint, long, CacheContext) - Constructor for class com.hazelcast.cache.impl.client.CacheInvalidationListener
-  
- CacheInvalidationMessage - Class in com.hazelcast.cache.impl.client
-  
- CacheInvalidationMessage() - Constructor for class com.hazelcast.cache.impl.client.CacheInvalidationMessage
-  
- CacheInvalidationMessage(String) - Constructor for class com.hazelcast.cache.impl.client.CacheInvalidationMessage
-  
- CacheIterateMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CacheIterateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheIterateMessageTask
-  
- CacheIterateRequest - Class in com.hazelcast.cache.impl.client
- 
- CacheIterateRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheIterateRequest
-  
- CacheIterateRequest(String, int, int, int, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheIterateRequest
-  
- CacheKeyIteratorOperation - Class in com.hazelcast.cache.impl.operation
- 
Provides iterator functionality for ICache. 
- CacheKeyIteratorOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheKeyIteratorOperation
-  
- CacheKeyIteratorOperation(String, int, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheKeyIteratorOperation
-  
- CacheKeyIteratorResult - Class in com.hazelcast.cache.impl
- 
- CacheKeyIteratorResult() - Constructor for class com.hazelcast.cache.impl.CacheKeyIteratorResult
-  
- CacheKeyIteratorResult(List<Data>, int) - Constructor for class com.hazelcast.cache.impl.CacheKeyIteratorResult
-  
- CacheListenerRegistrationMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CacheListenerRegistrationMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
-  
- CacheListenerRegistrationOperation - Class in com.hazelcast.cache.impl.operation
- 
Listener can be registered and unregistered by  CacheService. 
- CacheListenerRegistrationOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
-  
- CacheListenerRegistrationOperation(String, CacheEntryListenerConfiguration, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
-  
- CacheListenerRegistrationRequest - Class in com.hazelcast.cache.impl.client
- 
- CacheListenerRegistrationRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
-  
- CacheListenerRegistrationRequest(String, CacheEntryListenerConfiguration, boolean, Address) - Constructor for class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
-  
- CacheLoadAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CacheLoadAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
-  
- CacheLoadAllOperation - Class in com.hazelcast.cache.impl.operation
- 
- CacheLoadAllOperation(String, Set<Data>, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-  
- CacheLoadAllOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-  
- CacheLoadAllOperationFactory - Class in com.hazelcast.cache.impl.operation
- 
- CacheLoadAllOperationFactory(String, Set<Data>, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
-  
- CacheLoadAllOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
-  
- CacheLoadAllRequest - Class in com.hazelcast.cache.impl.client
- 
- CacheLoadAllRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-  
- CacheLoadAllRequest(String, Set<Data>, boolean) - Constructor for class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-  
- cacheLoader - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- cacheLocalEntries - Variable in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- CacheManagementConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CacheManagementConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
-  
- CacheManagementConfigOperation - Class in com.hazelcast.cache.impl.operation
- 
Cache ManagementConfig Operation provides enabling/disabling the functionality of  management and
 statistics mxbeans of the cache. 
- CacheManagementConfigOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
-  
- CacheManagementConfigOperation(String, boolean, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
-  
- CacheManagementConfigRequest - Class in com.hazelcast.cache.impl.client
- 
- CacheManagementConfigRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheManagementConfigRequest
-  
- CacheManagementConfigRequest(String, boolean, boolean, Address) - Constructor for class com.hazelcast.cache.impl.client.CacheManagementConfigRequest
-  
- CacheManagerBeanDefinitionParser - Class in com.hazelcast.spring
- 
Bean definition parser for JCache  CacheManagerSample bean
- CacheManagerBeanDefinitionParser() - Constructor for class com.hazelcast.spring.CacheManagerBeanDefinitionParser
-  
- CacheMergeOperation - Class in com.hazelcast.cache.impl.operation
-  
- CacheMergeOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheMergeOperation
-  
- CacheMergeOperation(String, Data, CacheEntryView<Data, Data>, CacheMergePolicy) - Constructor for class com.hazelcast.cache.impl.operation.CacheMergeOperation
-  
- CacheMergePolicy - Interface in com.hazelcast.cache
- 
 Policy for merging cache entries. 
- CacheMergePolicyProvider - Class in com.hazelcast.cache.impl.merge.policy
- 
- CacheMergePolicyProvider(NodeEngine) - Constructor for class com.hazelcast.cache.impl.merge.policy.CacheMergePolicyProvider
-  
- CacheMXBeanImpl - Class in com.hazelcast.cache.impl
- 
Implementation of CacheMXBean.
 
- CacheMXBeanImpl(CacheConfig) - Constructor for class com.hazelcast.cache.impl.CacheMXBeanImpl
-  
- cacheNamePrefix - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- cacheNamePrefix() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
- 
This method calculates a fixed string based on the URI and classloader using the formula: 
- CacheNotExistsException - Exception in com.hazelcast.cache
- 
This exception class is thrown while creating  CacheRecordStore
 instances but the cache config does not exist on the node to create the instance on. 
- CacheNotExistsException(String) - Constructor for exception com.hazelcast.cache.CacheNotExistsException
-  
- CacheObjectRecord - Class in com.hazelcast.cache.impl.record
- 
Implementation of  CacheRecord which has an internal object format. 
- CacheObjectRecord() - Constructor for class com.hazelcast.cache.impl.record.CacheObjectRecord
-  
- CacheObjectRecord(Object, long, long) - Constructor for class com.hazelcast.cache.impl.record.CacheObjectRecord
-  
- CacheOperationProvider - Interface in com.hazelcast.cache.impl
- 
Provide InMemoryFormat specific operations for cache 
- CachePartitionEventData - Class in com.hazelcast.cache.impl
-  
- CachePartitionEventData(String, int, Member) - Constructor for class com.hazelcast.cache.impl.CachePartitionEventData
-  
- CachePartitionLostEvent - Class in com.hazelcast.cache.impl.event
- 
Used to provide information about the lost partition of a cache. 
- CachePartitionLostEvent(Object, Member, int, int) - Constructor for class com.hazelcast.cache.impl.event.CachePartitionLostEvent
-  
- CachePartitionLostEventFilter - Class in com.hazelcast.cache.impl.event
- 
Used to filter partition lost listener events 
- CachePartitionLostEventFilter() - Constructor for class com.hazelcast.cache.impl.event.CachePartitionLostEventFilter
-  
- CachePartitionLostListener - Interface in com.hazelcast.cache.impl.event
- 
Invoked when owner and all backups of a partition are lost for a specific cache. 
- CachePartitionLostListenerConfig - Class in com.hazelcast.config
- 
Configuration for CachePartitionLostListener 
- CachePartitionLostListenerConfig() - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
-  
- CachePartitionLostListenerConfig(String) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
-  
- CachePartitionLostListenerConfig(CachePartitionLostListener) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
-  
- CachePartitionLostListenerConfig(CachePartitionLostListenerConfig) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
-  
- CachePartitionLostListenerConfigReadOnly - Class in com.hazelcast.config
- 
Read-Only Configuration for CachePartitionLostListener 
- CachePartitionLostListenerConfigReadOnly(CachePartitionLostListenerConfig) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfigReadOnly
-  
- CachePartitionSegment - Class in com.hazelcast.cache.impl
- 
     Responsible for all cache data of a partition. 
- CachePartitionSegment(AbstractCacheService, int) - Constructor for class com.hazelcast.cache.impl.CachePartitionSegment
-  
- CachePermission - Class in com.hazelcast.security.permission
-  
- CachePermission(String, String...) - Constructor for class com.hazelcast.security.permission.CachePermission
-  
- CachePortableHook - Class in com.hazelcast.cache.impl
- 
- CachePortableHook() - Constructor for class com.hazelcast.cache.impl.CachePortableHook
-  
- CacheProxy<K,V> - Class in com.hazelcast.cache.impl
- 
ICache implementation 
- CacheProxy(CacheConfig, NodeEngine, ICacheService, HazelcastServerCacheManager) - Constructor for class com.hazelcast.cache.impl.CacheProxy
-  
- CacheProxyUtil - Class in com.hazelcast.cache.impl
- 
Static util methods for  ICache implementations. 
- CachePutAllBackupOperation - Class in com.hazelcast.cache.impl.operation
- 
Cache PutAllBackup Operation is the backup operation used by load all operation. 
- CachePutAllBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
-  
- CachePutAllBackupOperation(String, Map<Data, CacheRecord>) - Constructor for class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
-  
- CachePutAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CachePutAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CachePutAllMessageTask
-  
- CachePutAllOperation - Class in com.hazelcast.cache.impl.operation
-  
- CachePutAllOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutAllOperation
-  
- CachePutAllOperation(String, List<Map.Entry<Data, Data>>, ExpiryPolicy, int) - Constructor for class com.hazelcast.cache.impl.operation.CachePutAllOperation
-  
- CachePutAllRequest - Class in com.hazelcast.cache.impl.client
- 
This client request that puts entries as batch into specified partition. 
- CachePutAllRequest() - Constructor for class com.hazelcast.cache.impl.client.CachePutAllRequest
-  
- CachePutAllRequest(String, InMemoryFormat, List<Map.Entry<Data, Data>>, ExpiryPolicy, int) - Constructor for class com.hazelcast.cache.impl.client.CachePutAllRequest
-  
- CachePutBackupOperation - Class in com.hazelcast.cache.impl.operation
- 
Backup operation for the operation of adding cache entries into record stores. 
- CachePutBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutBackupOperation
-  
- CachePutBackupOperation(String, Data, CacheRecord) - Constructor for class com.hazelcast.cache.impl.operation.CachePutBackupOperation
-  
- CachePutBackupOperation(String, Data, CacheRecord, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CachePutBackupOperation
-  
- CachePutIfAbsentMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CachePutIfAbsentMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CachePutIfAbsentMessageTask
-  
- CachePutIfAbsentOperation - Class in com.hazelcast.cache.impl.operation
- 
- CachePutIfAbsentOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
-  
- CachePutIfAbsentOperation(String, Data, Data, ExpiryPolicy, int) - Constructor for class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
-  
- CachePutIfAbsentRequest - Class in com.hazelcast.cache.impl.client
- 
- CachePutIfAbsentRequest() - Constructor for class com.hazelcast.cache.impl.client.CachePutIfAbsentRequest
-  
- CachePutIfAbsentRequest(String, Data, Data, ExpiryPolicy, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CachePutIfAbsentRequest
-  
- CachePutMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CachePutMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CachePutMessageTask
-  
- CachePutOperation - Class in com.hazelcast.cache.impl.operation
- 
- CachePutOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutOperation
-  
- CachePutOperation(String, Data, Data, ExpiryPolicy, boolean, int) - Constructor for class com.hazelcast.cache.impl.operation.CachePutOperation
-  
- CachePutRequest - Class in com.hazelcast.cache.impl.client
- 
- CachePutRequest() - Constructor for class com.hazelcast.cache.impl.client.CachePutRequest
-  
- CachePutRequest(String, Data, Data, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CachePutRequest
-  
- CachePutRequest(String, Data, Data, ExpiryPolicy, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CachePutRequest
-  
- CachePutRequest(String, Data, Data, ExpiryPolicy, boolean, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CachePutRequest
-  
- CacheRecord<V> - Interface in com.hazelcast.cache.impl.record
- 
 An expirable and evictable data object which represents a cache entry. 
- cacheRecordFactory - Variable in class com.hazelcast.cache.impl.CacheRecordStore
-  
- CacheRecordFactory<R extends CacheRecord> - Class in com.hazelcast.cache.impl.record
- 
- CacheRecordFactory(InMemoryFormat, SerializationService) - Constructor for class com.hazelcast.cache.impl.record.CacheRecordFactory
-  
- CacheRecordHashMap - Class in com.hazelcast.cache.impl.record
-  
- CacheRecordHashMap(int, CacheContext) - Constructor for class com.hazelcast.cache.impl.record.CacheRecordHashMap
-  
- CacheRecordHashMap.EvictableSamplingEntry - Class in com.hazelcast.cache.impl.record
-  
- CacheRecordHashMap.EvictableSamplingEntry(Data, CacheRecord) - Constructor for class com.hazelcast.cache.impl.record.CacheRecordHashMap.EvictableSamplingEntry
-  
- CacheRecordMap<K extends Data,V extends CacheRecord> - Interface in com.hazelcast.cache.impl.record
- 
- cacheRecordStore - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-  
- CacheRecordStore - Class in com.hazelcast.cache.impl
- 
- CacheRecordStore(String, int, NodeEngine, AbstractCacheService) - Constructor for class com.hazelcast.cache.impl.CacheRecordStore
-  
- CacheRemoveAllBackupOperation - Class in com.hazelcast.cache.impl.operation
- 
- CacheRemoveAllBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
-  
- CacheRemoveAllBackupOperation(String, Set<Data>) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
-  
- CacheRemoveAllKeysMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CacheRemoveAllKeysMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
-  
- CacheRemoveAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CacheRemoveAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
-  
- CacheRemoveAllOperation - Class in com.hazelcast.cache.impl.operation
- 
TODO add a proper JavaDoc 
- CacheRemoveAllOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
-  
- CacheRemoveAllOperation(String, Set<Data>, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
-  
- CacheRemoveAllOperationFactory - Class in com.hazelcast.cache.impl.operation
- 
- CacheRemoveAllOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
-  
- CacheRemoveAllOperationFactory(String, Set<Data>, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
-  
- CacheRemoveBackupOperation - Class in com.hazelcast.cache.impl.operation
- 
Backup operation used by remove operations. 
- CacheRemoveBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
-  
- CacheRemoveBackupOperation(String, Data) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
-  
- CacheRemoveBackupOperation(String, Data, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
-  
- CacheRemoveEntryListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
Client request which unregisters the event listener on behalf of the client. 
- CacheRemoveEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
-  
- CacheRemoveEntryListenerRequest - Class in com.hazelcast.cache.impl.client
- 
Client request which unregisters the event listener on behalf of the client. 
- CacheRemoveEntryListenerRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheRemoveEntryListenerRequest
-  
- CacheRemoveEntryListenerRequest(String) - Constructor for class com.hazelcast.cache.impl.client.CacheRemoveEntryListenerRequest
-  
- CacheRemoveInvalidationListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
Client request which unregisters the invalidation listener on behalf of the client. 
- CacheRemoveInvalidationListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
-  
- CacheRemoveInvalidationListenerRequest - Class in com.hazelcast.cache.impl.client
- 
Client request which unregisters the invalidation listener on behalf of the client. 
- CacheRemoveInvalidationListenerRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheRemoveInvalidationListenerRequest
-  
- CacheRemoveInvalidationListenerRequest(String) - Constructor for class com.hazelcast.cache.impl.client.CacheRemoveInvalidationListenerRequest
-  
- CacheRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CacheRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveMessageTask
-  
- CacheRemoveOperation - Class in com.hazelcast.cache.impl.operation
- 
Operation implementation for cache remove functionality. 
- CacheRemoveOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveOperation
-  
- CacheRemoveOperation(String, Data, Data, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveOperation
-  
- CacheRemovePartitionLostListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-  
- CacheRemovePartitionLostListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
-  
- CacheRemovePartitionLostListenerRequest - Class in com.hazelcast.cache.impl.client
-  
- CacheRemovePartitionLostListenerRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheRemovePartitionLostListenerRequest
-  
- CacheRemovePartitionLostListenerRequest(String) - Constructor for class com.hazelcast.cache.impl.client.CacheRemovePartitionLostListenerRequest
-  
- CacheRemoveRequest - Class in com.hazelcast.cache.impl.client
- 
- CacheRemoveRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheRemoveRequest
-  
- CacheRemoveRequest(String, Data, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheRemoveRequest
-  
- CacheRemoveRequest(String, Data, Data, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheRemoveRequest
-  
- CacheReplaceMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CacheReplaceMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheReplaceMessageTask
-  
- CacheReplaceOperation - Class in com.hazelcast.cache.impl.operation
- 
Operator implementation for cache replace functionality. 
- CacheReplaceOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheReplaceOperation
-  
- CacheReplaceOperation(String, Data, Data, Data, ExpiryPolicy, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheReplaceOperation
-  
- CacheReplaceRequest - Class in com.hazelcast.cache.impl.client
- 
- CacheReplaceRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheReplaceRequest
-  
- CacheReplaceRequest(String, Data, Data, ExpiryPolicy, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheReplaceRequest
-  
- CacheReplaceRequest(String, Data, Data, Data, ExpiryPolicy, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheReplaceRequest
-  
- CacheReplicationOperation - Class in com.hazelcast.cache.impl.operation
- 
- CacheReplicationOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheReplicationOperation
-  
- CacheReplicationOperation(CachePartitionSegment, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheReplicationOperation
-  
- caches - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- cacheService - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- cacheService - Variable in class com.hazelcast.cache.impl.CachePartitionSegment
-  
- CacheService - Class in com.hazelcast.cache.impl
- 
Cache Service is the main access point of JCache implementation. 
- CacheService() - Constructor for class com.hazelcast.cache.impl.CacheService
-  
- CacheSimpleConfig - Class in com.hazelcast.config
- 
Simple configuration to hold parsed XML configuration. 
- CacheSimpleConfig(CacheSimpleConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfig
-  
- CacheSimpleConfig() - Constructor for class com.hazelcast.config.CacheSimpleConfig
-  
- CacheSimpleConfig.ExpiryPolicyFactoryConfig - Class in com.hazelcast.config
- 
Represents configuration for "ExpiryPolicyFactory". 
- CacheSimpleConfig.ExpiryPolicyFactoryConfig(String) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
-  
- CacheSimpleConfig.ExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
-  
- CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig - Class in com.hazelcast.config
- 
Represents duration configuration with duration amount and time unit
 for the "TimedExpiryPolicyFactoryConfig". 
- CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig(long, TimeUnit) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
-  
- CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig - Class in com.hazelcast.config
- 
Represents configuration for time based "ExpiryPolicyFactory" with duration and time unit. 
- CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType, CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
-  
- CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType - Enum in com.hazelcast.config
- 
Represents type of the "TimedExpiryPolicyFactoryConfig". 
- CacheSimpleConfigReadOnly - Class in com.hazelcast.config
- 
- CacheSimpleConfigReadOnly(CacheSimpleConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- CacheSimpleEntryListenerConfig - Class in com.hazelcast.config
- 
Simple configuration to hold parsed listener config 
- CacheSimpleEntryListenerConfig(CacheSimpleEntryListenerConfig) - Constructor for class com.hazelcast.config.CacheSimpleEntryListenerConfig
-  
- CacheSimpleEntryListenerConfig() - Constructor for class com.hazelcast.config.CacheSimpleEntryListenerConfig
-  
- CacheSimpleEntryListenerConfigReadOnly - Class in com.hazelcast.config
- 
Readonly version of CacheSimpleEntryListenerConfig 
- CacheSimpleEntryListenerConfigReadOnly(CacheSimpleEntryListenerConfig) - Constructor for class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
-  
- CacheSingleInvalidationMessage - Class in com.hazelcast.cache.impl.client
-  
- CacheSingleInvalidationMessage() - Constructor for class com.hazelcast.cache.impl.client.CacheSingleInvalidationMessage
-  
- CacheSingleInvalidationMessage(String, Data, String) - Constructor for class com.hazelcast.cache.impl.client.CacheSingleInvalidationMessage
-  
- CacheSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
- 
- CacheSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheSizeMessageTask
-  
- CacheSizeOperation - Class in com.hazelcast.cache.impl.operation
- 
This operation implementation is for calculating the cluster size of a named cache. 
- CacheSizeOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheSizeOperation
-  
- CacheSizeOperation(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheSizeOperation
-  
- CacheSizeOperationFactory - Class in com.hazelcast.cache.impl.operation
- 
- CacheSizeOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
-  
- CacheSizeOperationFactory(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
-  
- CacheSizeRequest - Class in com.hazelcast.cache.impl.client
- 
- CacheSizeRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheSizeRequest
-  
- CacheSizeRequest(String) - Constructor for class com.hazelcast.cache.impl.client.CacheSizeRequest
-  
- cacheSplitBrainHandler - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-  
- CacheStatistics - Interface in com.hazelcast.cache
- 
Cache statistics 
- cacheStatisticsConstructorFunction - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-  
- CacheStatisticsImpl - Class in com.hazelcast.cache.impl
- 
- CacheStatisticsImpl(long, CacheEntryCountResolver) - Constructor for class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- CacheStatisticsMXBeanImpl - Class in com.hazelcast.cache.impl
- 
Implementation of CacheStatisticsMXBean
 
- CacheStatisticsMXBeanImpl(CacheStatisticsImpl) - Constructor for class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-  
- CacheSyncListenerCompleter - Interface in com.hazelcast.cache.impl
- 
used to state that a sync event completed and any resources waiting for it should be released 
- CacheWanEventPublisher - Interface in com.hazelcast.cache.impl.event
- 
This interface provides methods to publish wan replication events
 from cache operations. 
- cacheWriter - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- cachingProvider - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- calculateDataSize(String) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-  
- calculateDataSize(Data) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-  
- calculateDataSize(Map.Entry<Data, Data>) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-  
- calculateDataSize(byte[]) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-  
- calculateDataSize(Integer) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-  
- calculateDataSize(Boolean) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-  
- calculateExpirationWithDelay(long, long, boolean) - Static method in class com.hazelcast.map.impl.ExpirationTimeSetter
- 
On backup partitions, this method delays key`s expiration. 
- calculateMaxIdleMillis(MapConfig) - Static method in class com.hazelcast.map.impl.ExpirationTimeSetter
-  
- calculateMaxPartitionSize(int, int) - Static method in class com.hazelcast.cache.impl.maxsize.impl.EntryCountCacheMaxSizeChecker
-  
- calculateObjectName(String, String, boolean) - Static method in class com.hazelcast.cache.impl.MXBeanUtil
- 
Creates an object name using the scheme. 
- calculatePartitionHash(Object, PartitioningStrategy) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- calculatePerNodeMaxRecordStoreSize(RecordStore) - Method in class com.hazelcast.map.impl.eviction.EvictionCheckerImpl
- 
Calculates and returns the expected maximum size of an evicted record-store
 when  PER_NODE max-size-policy is used. 
- calculateSize(NearCacheRecord) - Method in class com.hazelcast.map.impl.nearcache.NearCacheSizeEstimator
-  
- calculateSize(T) - Method in interface com.hazelcast.map.impl.SizeEstimator
-  
- calculateTTLMillis(MapConfig) - Static method in class com.hazelcast.map.impl.ExpirationTimeSetter
-  
- call() - Method in class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
-  
- call() - Method in class com.hazelcast.cache.impl.client.CacheAddInvalidationListenerRequest
-  
- call() - Method in class com.hazelcast.cache.impl.client.CacheAddPartitionLostListenerRequest
-  
- call() - Method in class com.hazelcast.client.impl.client.AddDistributedObjectListenerRequest
-  
- call() - Method in class com.hazelcast.client.impl.client.AuthenticationRequest
-  
- call() - Method in class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
-  
- call() - Method in class com.hazelcast.client.impl.client.ClientDestroyRequest
-  
- call() - Method in class com.hazelcast.client.impl.client.GetMemberListRequest
-  
- call() - Method in class com.hazelcast.client.impl.client.RemoveAllListeners
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.AbstractCallableMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMultiPartitionMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.AbstractRemoveListenerMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.AbstractTransactionalMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddEntryListenerMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddInvalidationListenerTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.AbstractExecutorServiceCancelMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddListenerMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapAddEntryListenerMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapQueryMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceCancelMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceJobProcessInformationMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.multimap.AbstractMultiMapAddEntryListenerMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddListenerMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicAddMessageListenerMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAClearRemoteTransactionMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCommitMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCreateMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionPrepareMessageTask
-  
- call() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionRollbackMessageTask
-  
- call() - Method in class com.hazelcast.cluster.client.AddMembershipListenerRequest
-  
- call() - Method in class com.hazelcast.cluster.client.ClientPingRequest
-  
- call() - Method in class com.hazelcast.cluster.client.RegisterMembershipListenerRequest
-  
- call() - Method in class com.hazelcast.collection.impl.collection.client.CollectionAddListenerRequest
-  
- call() - Method in class com.hazelcast.collection.impl.queue.client.AddListenerRequest
-  
- call() - Method in class com.hazelcast.console.Echo
-  
- call() - Method in class com.hazelcast.console.SimulateLoadTask
-  
- call() - Method in class com.hazelcast.executor.impl.client.IsShutdownRequest
-  
- call() - Method in class com.hazelcast.executor.impl.client.ShutdownRequest
-  
- call() - Method in class com.hazelcast.executor.impl.RunnableAdapter
-  
- call() - Method in class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-  
- call() - Method in class com.hazelcast.map.impl.client.MapAddPartitionLostListenerRequest
-  
- call() - Method in class com.hazelcast.map.impl.query.MapQueryEngineImpl.QueryPartitionCallable
-  
- call() - Method in class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-  
- call() - Method in class com.hazelcast.partition.client.AddPartitionLostListenerRequest
-  
- call() - Method in class com.hazelcast.partition.client.GetPartitionsRequest
-  
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
-  
- call() - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-  
- call() - Method in class com.hazelcast.transaction.client.BaseTransactionRequest
-  
- call() - Method in class com.hazelcast.transaction.client.ClearRemoteTransactionRequest
-  
- call() - Method in class com.hazelcast.transaction.client.CommitXATransactionRequest
-  
- call() - Method in class com.hazelcast.transaction.client.CreateXATransactionRequest
-  
- call() - Method in class com.hazelcast.transaction.client.PrepareXATransactionRequest
-  
- call() - Method in class com.hazelcast.transaction.client.RollbackXATransactionRequest
-  
- CALL_ID_LOCAL_SKIPPED - Static variable in class com.hazelcast.spi.Operation
- 
A call id for an invocation that is skipping local registration. 
- CALL_TIMEOUT_RESPONSE - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
-  
- CALLABLE_TASK - Static variable in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
-  
- CallableClientRequest - Class in com.hazelcast.client.impl.client
-  
- CallableClientRequest() - Constructor for class com.hazelcast.client.impl.client.CallableClientRequest
-  
- CallableTaskOperation - Class in com.hazelcast.executor.impl.operations
-  
- CallableTaskOperation() - Constructor for class com.hazelcast.executor.impl.operations.CallableTaskOperation
-  
- CallableTaskOperation(String, String, Data) - Constructor for class com.hazelcast.executor.impl.operations.CallableTaskOperation
-  
- callAfterStoreListeners(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessor
-  
- Callback<T> - Interface in com.hazelcast.spi
- 
Deprecated. 
- callback - Variable in class com.hazelcast.spi.InvocationBuilder
-  
- callBeforeStoreListeners(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessor
-  
- CALLER_NOT_MEMBER - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- CallerNotMemberException - Exception in com.hazelcast.spi.exception
- 
A  RetryableHazelcastException that indicates that an operation was send by a machine which isn't member
 in the cluster when the operation is executed. 
- CallerNotMemberException(Address, Address, int, String, String) - Constructor for exception com.hazelcast.spi.exception.CallerNotMemberException
-  
- CallerNotMemberException(String) - Constructor for exception com.hazelcast.spi.exception.CallerNotMemberException
-  
- callId - Variable in class com.hazelcast.client.impl.client.ClientRequest
-  
- callId - Variable in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
-  
- CallIdSequence - Class in com.hazelcast.client.spi.impl
-  
- CallIdSequence() - Constructor for class com.hazelcast.client.spi.impl.CallIdSequence
-  
- CallIdSequence - Class in com.hazelcast.spi.impl.operationservice.impl
- 
Responsible for generating callIds. 
- CallIdSequence() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.CallIdSequence
-  
- CallIdSequence.CallIdSequenceFailFast - Class in com.hazelcast.client.spi.impl
- 
A  CallIdSequence that provided backpressure by taking
 the number in flight operations into account when a call-id needs to be determined. 
- CallIdSequence.CallIdSequenceFailFast(int) - Constructor for class com.hazelcast.client.spi.impl.CallIdSequence.CallIdSequenceFailFast
-  
- CallIdSequence.CallIdSequenceWithBackpressure - Class in com.hazelcast.spi.impl.operationservice.impl
- 
A  CallIdSequence that provided backpressure by taking
 the number in flight operations into account when a call-id needs to be determined. 
- CallIdSequence.CallIdSequenceWithBackpressure(int, long) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.CallIdSequence.CallIdSequenceWithBackpressure
-  
- CallIdSequence.CallIdSequenceWithoutBackpressure - Class in com.hazelcast.spi.impl.operationservice.impl
-  
- CallIdSequence.CallIdSequenceWithoutBackpressure() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.CallIdSequence.CallIdSequenceWithoutBackpressure
-  
- callOnAddress(Address, Operation) - Method in class com.hazelcast.internal.management.ManagementCenterService
-  
- callOnMember(Member, Operation) - Method in class com.hazelcast.internal.management.ManagementCenterService
-  
- callOnThis(Operation) - Method in class com.hazelcast.internal.management.ManagementCenterService
-  
- callTimeout - Variable in class com.hazelcast.spi.InvocationBuilder
-  
- CallTimeoutResponse - Class in com.hazelcast.spi.impl.operationservice.impl.responses
- 
An response that indicates that the execution of a single call ran into a timeout. 
- CallTimeoutResponse() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.responses.CallTimeoutResponse
-  
- CallTimeoutResponse(long, boolean) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.responses.CallTimeoutResponse
-  
- canAcquireLock(Data, String, long) - Method in interface com.hazelcast.concurrent.lock.LockStore
-  
- canAcquireLock(Data, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- canAcquireLock(Data, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
-  
- canAcquireLock(Data, String, long) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- canAcquireLock(Data, String, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- canAcquireLock(Data, String, long) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-  
- cancel(boolean) - Method in class com.hazelcast.client.spi.impl.ClientInvocationFuture
-  
- cancel(boolean) - Method in class com.hazelcast.client.util.ClientAddressCancellableDelegatingFuture
-  
- cancel(boolean) - Method in class com.hazelcast.client.util.ClientCancellableDelegatingFuture
-  
- cancel(boolean) - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-  
- cancel(boolean) - Method in class com.hazelcast.client.util.ClientPartitionCancellableDelegatingFuture
-  
- cancel(String, boolean) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-  
- cancel() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-  
- cancel() - Method in class com.hazelcast.mapreduce.impl.task.MapCombineTask
-  
- cancel() - Method in class com.hazelcast.mapreduce.impl.task.MappingPhase
-  
- cancel() - Method in class com.hazelcast.mapreduce.impl.task.ReducerTask
-  
- cancel(boolean) - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-  
- cancel(boolean) - Method in class com.hazelcast.util.executor.CompletedFuture
-  
- cancel(boolean) - Method in class com.hazelcast.util.executor.DelegatingFuture
-  
- cancel(K) - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
-  
- CANCEL_JOB_SUPERVISOR_OPERATION - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-  
- cancelAll() - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
-  
- cancelAndNotify(Exception) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-  
- cancelEviction(String) - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- cancelEvictionIfExists() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- cancelExecution() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-  
- cancelIfExists(K, V) - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
-  
- CancelJobSupervisorOperation - Class in com.hazelcast.mapreduce.impl.operation
- 
This operation is fired by the jobs owner node to remotely cancel the defined jobId on all nodes. 
- CancelJobSupervisorOperation() - Constructor for class com.hazelcast.mapreduce.impl.operation.CancelJobSupervisorOperation
-  
- CancelJobSupervisorOperation(String, String) - Constructor for class com.hazelcast.mapreduce.impl.operation.CancelJobSupervisorOperation
-  
- CANCELLATION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- CANCELLATION_REQUEST - Static variable in class com.hazelcast.executor.impl.ExecutorPortableHook
-  
- CancellationOperation - Class in com.hazelcast.executor.impl.operations
-  
- CancellationOperation() - Constructor for class com.hazelcast.executor.impl.operations.CancellationOperation
-  
- CancellationOperation(String, boolean) - Constructor for class com.hazelcast.executor.impl.operations.CancellationOperation
-  
- CancellationRequest - Class in com.hazelcast.executor.impl.client
-  
- CancellationRequest() - Constructor for class com.hazelcast.executor.impl.client.CancellationRequest
-  
- CancellationRequest(String, Address, boolean) - Constructor for class com.hazelcast.executor.impl.client.CancellationRequest
-  
- CancellationRequest(String, int, boolean) - Constructor for class com.hazelcast.executor.impl.client.CancellationRequest
-  
- cancelled - Variable in class com.hazelcast.client.util.ClientCancellableDelegatingFuture
-  
- cancelled(boolean) - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
- 
Protected method invoked when this task transitions to state
 isCancelled.
 
- cancelled(boolean) - Method in class com.hazelcast.util.executor.CompletableFutureTask
-  
- cancelPartitionState() - Method in class com.hazelcast.mapreduce.impl.task.JobProcessInformationImpl
-  
- cancelReplicaSyncRequestsTo(Address) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- cancelTtlEntry(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-  
- cancelTtlEntry(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- cancelWaitingOps(String, Object, Throwable) - Method in class com.hazelcast.spi.impl.waitnotifyservice.impl.WaitNotifyServiceImpl
-  
- cancelWaitingOps(String, Object, Throwable) - Method in interface com.hazelcast.spi.impl.waitnotifyservice.InternalWaitNotifyService
-  
- canTransformResource(String) - Method in class com.hazelcast.buildutils.HazelcastManifestTransformer
-  
- capacity() - Method in class com.hazelcast.client.impl.protocol.util.BufferBuilder
- 
The current capacity of the buffer. 
- capacity() - Method in interface com.hazelcast.client.impl.protocol.util.ClientProtocolBuffer
- 
Get the capacity of the underlying buffer. 
- capacity() - Method in class com.hazelcast.client.impl.protocol.util.SafeBuffer
-  
- capacity() - Method in class com.hazelcast.client.impl.protocol.util.UnsafeBuffer
-  
- capacity() - Method in class com.hazelcast.client.proxy.ClientRingbufferProxy
-  
- CAPACITY - Static variable in class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
-  
- capacity() - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
-  
- capacity() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
- 
Returns the capacity of this Ringbuffer. 
- capacity() - Method in class com.hazelcast.util.collection.BiInt2ObjectMap
- 
Get the total capacity for the map to which the load factor with be a fraction of. 
- capacity() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
- 
Get the total capacity for the map to which the load factor with be a fraction of. 
- capacity() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
- 
Get the total capacity for the map to which the load factor with be a fraction of. 
- CapacityRequest - Class in com.hazelcast.ringbuffer.impl.client
-  
- CapacityRequest() - Constructor for class com.hazelcast.ringbuffer.impl.client.CapacityRequest
-  
- CapacityRequest(String) - Constructor for class com.hazelcast.ringbuffer.impl.client.CapacityRequest
-  
- casCachedValue(Object, Object) - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- casCachedValue(Object, Object) - Method in interface com.hazelcast.map.impl.record.Record
- 
Atomically sets the cached value to the given new value
 if the current cached value ==the expected value.
 
- cd - Variable in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- CDL_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- CDL_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- CDL_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- CDL_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- changeClusterState(ClusterState) - Method in class com.hazelcast.client.proxy.ClientClusterProxy
-  
- changeClusterState(ClusterState, TransactionOptions) - Method in class com.hazelcast.client.proxy.ClientClusterProxy
-  
- changeClusterState(ClusterState) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- changeClusterState(ClusterState, TransactionOptions) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- changeClusterState(ClusterState) - Method in interface com.hazelcast.core.Cluster
- 
Changes state of the cluster to the given state transactionally. 
- changeClusterState(ClusterState, TransactionOptions) - Method in interface com.hazelcast.core.Cluster
- 
Changes state of the cluster to the given state transactionally. 
- ChangeClusterStateOperation - Class in com.hazelcast.cluster.impl.operations
-  
- ChangeClusterStateOperation() - Constructor for class com.hazelcast.cluster.impl.operations.ChangeClusterStateOperation
-  
- ChangeClusterStateOperation(ClusterState, Address, String) - Constructor for class com.hazelcast.cluster.impl.operations.ChangeClusterStateOperation
-  
- ChangeClusterStateRequest - Class in com.hazelcast.internal.management.request
- 
Request coming from Management Center for changing the  ClusterState
- ChangeClusterStateRequest() - Constructor for class com.hazelcast.internal.management.request.ChangeClusterStateRequest
-  
- ChangeClusterStateRequest(String) - Constructor for class com.hazelcast.internal.management.request.ChangeClusterStateRequest
-  
- changeNodeStateToActive() - Method in class com.hazelcast.instance.Node
-  
- changeNodeStateToPassive() - Method in class com.hazelcast.instance.Node
-  
- changeSessionId() - Method in class com.hazelcast.web.WebFilter.RequestWrapper
-  
- ChangeWanStateOperation - Class in com.hazelcast.internal.management.operation
- 
- ChangeWanStateOperation() - Constructor for class com.hazelcast.internal.management.operation.ChangeWanStateOperation
-  
- ChangeWanStateOperation(String, String, boolean) - Constructor for class com.hazelcast.internal.management.operation.ChangeWanStateOperation
-  
- ChangeWanStateRequest - Class in com.hazelcast.internal.management.request
- 
- ChangeWanStateRequest() - Constructor for class com.hazelcast.internal.management.request.ChangeWanStateRequest
-  
- ChangeWanStateRequest(String, String, boolean) - Constructor for class com.hazelcast.internal.management.request.ChangeWanStateRequest
-  
- CHAR_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
-  
- CHAR_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
-  
- CHAR_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
-  
- CHAR_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
- 
Char size in bytes 
- check(Node, String, boolean) - Method in class com.hazelcast.util.PhoneHome
-  
- CHECK_EVICT - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-  
- checkAllDone(Collection<Future>) - Static method in class com.hazelcast.util.FutureUtil
- 
Rethrow exeception of the fist future that completed with an exception 
- CheckAndEvictOperation - Class in com.hazelcast.collection.impl.queue.operations
- 
Provides eviction functionality for Operations of Queue. 
- CheckAndEvictOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.CheckAndEvictOperation
-  
- CheckAndEvictOperation(String) - Constructor for class com.hazelcast.collection.impl.queue.operations.CheckAndEvictOperation
-  
- checkAssignedMembersAvailable(Collection<Address>) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-  
- checkAssignedMembersAvailable() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-  
- checkAsyncBackupCount(int, int) - Static method in class com.hazelcast.util.Preconditions
- 
Tests if the newAsyncBackupCount count is valid. 
- checkAvailable() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- checkBackupCount(int, int) - Static method in class com.hazelcast.util.Preconditions
- 
Tests if the newBackupCount count is valid. 
- checkBlockableReadSequence(long) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-  
- checkClassDefErrors - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- checkEvictionPossible(RecordStore) - Method in interface com.hazelcast.map.impl.eviction.EvictionChecker
- 
Check whether the supplied record-store needs eviction. 
- checkEvictionPossible(RecordStore) - Method in class com.hazelcast.map.impl.eviction.EvictionCheckerImpl
-  
- checkFalse(boolean, String) - Static method in class com.hazelcast.util.Preconditions
- 
Tests whether the supplied expression is false.
 
- checkFreeHeapPercentageEviction(MaxSizeConfig) - Method in class com.hazelcast.map.impl.eviction.EvictionCheckerImpl
-  
- checkFreeHeapSizeEviction(MaxSizeConfig) - Method in class com.hazelcast.map.impl.eviction.EvictionCheckerImpl
-  
- checkFullyProcessed(JobProcessInformation) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-  
- checkHasNext(Iterator<T>, String) - Static method in class com.hazelcast.util.Preconditions
- 
Check if iterator has next element. 
- checkHasText(String, String) - Static method in class com.hazelcast.util.Preconditions
- 
Tests if a string contains text. 
- checkHeapPercentageEviction(String, MaxSizeConfig) - Method in class com.hazelcast.map.impl.eviction.EvictionCheckerImpl
-  
- checkHeapSizeEviction(String, MaxSizeConfig) - Method in class com.hazelcast.map.impl.eviction.EvictionCheckerImpl
-  
- checkIfLoaded() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- checkIfLoaded() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- checkIfManagerNotClosed() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- checkIndexNotNegative(int) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-  
- checkInMemoryFormat(InMemoryFormat) - Static method in class com.hazelcast.map.impl.MapConfigValidator
- 
- checkInstanceOf(Class, E, String) - Static method in class com.hazelcast.util.Preconditions
- 
Tests whether the supplied object is an instance of the supplied class type. 
- checkNegative(long, String) - Static method in class com.hazelcast.util.Preconditions
- 
Tests if a long value is not negative. 
- checkNotInstanceOf(Class, E, String) - Static method in class com.hazelcast.util.Preconditions
- 
Tests the supplied object to see if it is not a type of the supplied class. 
- checkNotNegative(long, String) - Static method in class com.hazelcast.util.Preconditions
- 
Tests if a value is not negative. 
- checkNotNegative(int, String) - Static method in class com.hazelcast.util.Preconditions
- 
Tests if a value is not negative. 
- checkNotNull(T, String) - Static method in class com.hazelcast.util.Preconditions
- 
Tests if an argument is not null. 
- checkNotNull(T) - Static method in class com.hazelcast.util.Preconditions
- 
Tests if an argument is not null. 
- checkNotPagingPredicate(Predicate) - Method in class com.hazelcast.map.impl.query.MapQueryEngineImpl
-  
- checkObjectNotNull(Object) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-  
- checkObjectNotNull(Object) - Method in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
-  
- checkPermission(Subject, Permission) - Method in interface com.hazelcast.security.SecurityContext
- 
Checks whether current  Subject has been granted specified permission or not. 
- checkPerNodeEviction(RecordStore) - Method in class com.hazelcast.map.impl.eviction.EvictionCheckerImpl
-  
- checkPerPartitionEviction(String, MaxSizeConfig, int) - Method in class com.hazelcast.map.impl.eviction.EvictionCheckerImpl
-  
- checkPositive(long, String) - Static method in class com.hazelcast.util.Preconditions
- 
Tests if a value is positive; so larger than 0. 
- checkPositive(int, String) - Static method in class com.hazelcast.util.Preconditions
- 
Tests if a value is positive; larger than 0. 
- CheckReplicaVersion - Class in com.hazelcast.partition.impl
-  
- CheckReplicaVersion() - Constructor for class com.hazelcast.partition.impl.CheckReplicaVersion
-  
- CheckReplicaVersion(long, boolean) - Constructor for class com.hazelcast.partition.impl.CheckReplicaVersion
-  
- CheckReplicaVersion - Class in com.hazelcast.replicatedmap.impl.operation
- 
Checks whether replica version is in sync with the primary. 
- CheckReplicaVersion() - Constructor for class com.hazelcast.replicatedmap.impl.operation.CheckReplicaVersion
-  
- CheckReplicaVersion(PartitionContainer) - Constructor for class com.hazelcast.replicatedmap.impl.operation.CheckReplicaVersion
-  
- checkState(boolean, String) - Static method in class com.hazelcast.util.Preconditions
- 
Check the state of a condition 
- checkTransactionActive() - Method in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
-  
- checkTransactionActive() - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-  
- checkTransactionState() - Method in class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxySupport
-  
- checkTransactionState() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-  
- checkTrue(boolean, String) - Static method in class com.hazelcast.util.Preconditions
- 
Tests whether the supplied expression is true.
 
- checkWanReplicationQueues() - Method in class com.hazelcast.map.impl.MapContainer
-  
- checkWanReplicationQueues(String) - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
-  
- checkWanReplicationQueues() - Method in interface com.hazelcast.wan.WanReplicationPublisher
-  
- checkWanReplicationQueues(String) - Method in interface com.hazelcast.wan.WanReplicationService
-  
- childElements(Node) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
-  
- chunkSize - Variable in class com.hazelcast.mapreduce.impl.AbstractJob
-  
- chunkSize(int) - Method in class com.hazelcast.mapreduce.impl.AbstractJob
-  
- chunkSize(int) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.MappingJobImpl
-  
- chunkSize(int) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.ReducingJobImpl
-  
- chunkSize(int) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.ReducingSubmittableJobImpl
-  
- chunkSize - Variable in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-  
- chunkSize(int) - Method in interface com.hazelcast.mapreduce.Job
- 
Defines the number of elements per chunk. 
- chunkSize(int) - Method in interface com.hazelcast.mapreduce.MappingJob
- 
Defines the number of elements per chunk. 
- chunkSize(int) - Method in interface com.hazelcast.mapreduce.ReducingJob
- 
Defines the number of elements per chunk. 
- chunkSize(int) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
- 
Defines the number of elements per chunk. 
- CLASS_CAST - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- CLASS_NOT_FOUND - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- ClassDefinition - Interface in com.hazelcast.nio.serialization
- 
ClassDefinition defines a class schema for Portable classes. 
- ClassDefinitionBuilder - Class in com.hazelcast.nio.serialization
- 
ClassDefinitionBuilder is used to build and register ClassDefinitions manually. 
- ClassDefinitionBuilder(int, int) - Constructor for class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- ClassDefinitionBuilder(int, int, int) - Constructor for class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- ClassDefinitionImpl - Class in com.hazelcast.internal.serialization.impl
-  
- ClassDefinitionImpl(int, int, int) - Constructor for class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-  
- classDefinitions - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- ClassicOperationExecutor - Class in com.hazelcast.spi.impl.operationexecutor.classic
- 
- ClassicOperationExecutor(GroupProperties, LoggingService, Address, OperationRunnerFactory, HazelcastThreadGroup, NodeExtension, MetricsRegistry) - Constructor for class com.hazelcast.spi.impl.operationexecutor.classic.ClassicOperationExecutor
-  
- classIterator(String, ClassLoader) - Static method in class com.hazelcast.util.ServiceLoader
-  
- classLoader - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- classLoader - Variable in class com.hazelcast.util.executor.AbstractExecutorThreadFactory
-  
- classLoaderReference - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- ClassLoaderUtil - Class in com.hazelcast.nio
- 
Utility class to deal with classloaders. 
- ClassLoadingMetricSet - Class in com.hazelcast.internal.metrics.metricsets
- 
- className - Variable in class com.hazelcast.config.ListenerConfig
-  
- className - Variable in class com.hazelcast.config.PredicateConfig
-  
- className - Variable in class com.hazelcast.config.SecurityInterceptorConfig
-  
- ClasspathXmlConfig - Class in com.hazelcast.config
- 
A  Config which is initialized by loading an XML configuration file from the classpath. 
- ClasspathXmlConfig(String) - Constructor for class com.hazelcast.config.ClasspathXmlConfig
- 
Creates a config which is loaded from a classpath resource using the
 Thread.currentThread contextClassLoader. 
- ClasspathXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.ClasspathXmlConfig
- 
Creates a config which is loaded from a classpath resource using the
 Thread.currentThread contextClassLoader. 
- ClasspathXmlConfig(ClassLoader, String) - Constructor for class com.hazelcast.config.ClasspathXmlConfig
- 
Creates a config which is loaded from a classpath resource. 
- ClasspathXmlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.config.ClasspathXmlConfig
- 
Creates a config which is loaded from a classpath resource. 
- CleaningNearCacheInvalidation - Class in com.hazelcast.map.impl.nearcache
- 
Used when invalidating client near-caches. 
- CleaningNearCacheInvalidation() - Constructor for class com.hazelcast.map.impl.nearcache.CleaningNearCacheInvalidation
-  
- CleaningNearCacheInvalidation(String, String) - Constructor for class com.hazelcast.map.impl.nearcache.CleaningNearCacheInvalidation
-  
- cleanNodeName(Node) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
-  
- cleanup() - Method in class com.hazelcast.jca.ManagedConnectionImpl
-  
- cleanup() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
- 
Cleans up the ringbuffer by deleting all expired items. 
- cleanupService - Variable in class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
-  
- CleanupService - Class in com.hazelcast.hibernate.local
- 
An internal service to clean cache regions 
- CleanupService(String) - Constructor for class com.hazelcast.hibernate.local.CleanupService
-  
- clear() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- CLEAR - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- clear() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-  
- CLEAR - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- clear() - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- clear() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
- 
Implementation of CacheStatisticsMXBean.clear().
 
- clear() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-  
- clear() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
clears all internal data without publishing any events 
- clear() - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache
-  
- clear() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- clear() - Method in interface com.hazelcast.cache.impl.nearcache.NearCache
- 
Removes all stored values. 
- clear() - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheRecordStore
- 
Removes all stored values. 
- clear() - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap
-  
- clear() - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- clear() - Method in interface com.hazelcast.client.ClientEndpointManager
- 
Removes all endpoints. 
- clear() - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-  
- clear() - Method in class com.hazelcast.client.map.impl.nearcache.ClientHeapNearCache
-  
- clear() - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
-  
- clear() - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-  
- clear() - Method in class com.hazelcast.client.proxy.ClientListProxy
-  
- clear() - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- clear() - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-  
- clear() - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-  
- clear() - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-  
- clear() - Method in class com.hazelcast.client.proxy.ClientSetProxy
-  
- clear() - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- clear() - Method in class com.hazelcast.cluster.impl.MemberSelectingCollection
-  
- clear() - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-  
- clear() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- clear() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- CLEAR - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-  
- CLEAR - Static variable in class com.hazelcast.collection.impl.queue.QueuePortableHook
-  
- clear() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- clear() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- clear() - Method in class com.hazelcast.config.InterfacesConfig
- 
clears all interfaces. 
- clear() - Method in class com.hazelcast.config.MemberGroupConfig
- 
Removes all interfaces from the member group. 
- clear() - Method in class com.hazelcast.config.PartitionGroupConfig
- 
- clear() - Method in class com.hazelcast.config.ServicesConfig
-  
- clear() - Method in class com.hazelcast.config.TcpIpConfig
- 
Removes all members. 
- clear() - Method in interface com.hazelcast.core.IAtomicReference
- 
Clears the current stored reference. 
- clear() - Method in interface com.hazelcast.core.IMap
- 
- clear() - Method in interface com.hazelcast.core.MultiMap
- 
Clears the multimap. 
- clear() - Method in interface com.hazelcast.core.ReplicatedMap
- 
The clear operation wipes data out of the replicated maps. 
- clear() - Method in class com.hazelcast.hibernate.distributed.IMapRegionCache
-  
- clear() - Method in class com.hazelcast.hibernate.local.LocalRegionCache
-  
- clear() - Method in interface com.hazelcast.hibernate.RegionCache
-  
- clear() - Method in class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolThreadLocal
-  
- clear() - Method in class com.hazelcast.jmx.ListMBean
-  
- clear() - Method in class com.hazelcast.jmx.LockMBean
-  
- clear() - Method in class com.hazelcast.jmx.MapMBean
-  
- clear() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- clear() - Method in class com.hazelcast.jmx.QueueMBean
-  
- clear() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- clear() - Method in class com.hazelcast.jmx.SetMBean
-  
- CLEAR - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- clear() - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
- 
Clears resources of this map-data-store. 
- clear() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
- 
Removes all of the elements in this   WriteBehindQueue
 Queue will be empty after this method returns. 
- clear() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-  
- clear() - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
-  
- clear(String, boolean, String) - Method in class com.hazelcast.map.impl.nearcache.BatchInvalidator
-  
- clear() - Method in class com.hazelcast.map.impl.nearcache.NearCacheImpl
-  
- clear(String, boolean, String) - Method in interface com.hazelcast.map.impl.nearcache.NearCacheInvalidator
- 
Clears local and remote near-caches. 
- clear(String, boolean, String) - Method in class com.hazelcast.map.impl.nearcache.NonStopInvalidator
-  
- clear(boolean) - Method in class com.hazelcast.map.impl.PartitionContainer
-  
- clear() - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
- 
This method clears the map and deletaAll on MapStore which if connected to a database,
 will delete the records from that database. 
- clear() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- clear() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- clear() - Method in interface com.hazelcast.map.impl.recordstore.Storage
-  
- clear() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-  
- CLEAR - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- CLEAR - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-  
- clear() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-  
- clear() - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- clear() - Method in interface com.hazelcast.nio.BufferObjectDataOutput
-  
- clear() - Method in interface com.hazelcast.query.impl.Index
-  
- clear() - Method in class com.hazelcast.query.impl.IndexImpl
-  
- clear() - Method in interface com.hazelcast.query.impl.IndexStore
-  
- clear() - Method in class com.hazelcast.query.impl.SortedIndexStore
-  
- clear() - Method in class com.hazelcast.query.impl.UnsortedIndexStore
-  
- CLEAR - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-  
- clear() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-  
- clear() - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
-  
- clear() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- clear() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-  
- clear() - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
-  
- clear() - Method in class com.hazelcast.spring.cache.HazelcastCache
-  
- clear() - Method in class com.hazelcast.util.collection.InflatableSet
-  
- clear() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
- clear() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
-  
- clear() - Method in class com.hazelcast.util.collection.IntHashSet
- clear() - Method in class com.hazelcast.util.collection.Long2LongHashMap
- clear() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
- clear() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
-  
- clear() - Method in class com.hazelcast.util.collection.LongHashSet
- clear() - Method in class com.hazelcast.util.collection.MapDelegatingSet
- clear() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
- 
Removes all of the mappings from this map. 
- CLEAR_BACKUP - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- CLEAR_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-  
- CLEAR_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- CLEAR_FACTORY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- CLEAR_NEAR_CACHE - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- CLEAR_RESPONSE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- CLEAR_XA - Static variable in class com.hazelcast.transaction.client.ClientTxnPortableHook
-  
- clearAllListeners() - Method in interface com.hazelcast.client.ClientEndpoint
-  
- clearAllListeners() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- clearAllNearCaches() - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCacheManager
-  
- clearAllNearCaches() - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheManager
- 
- clearBackup(Set<Long>) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- clearBackup(Set<Long>) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- ClearBackupOperation - Class in com.hazelcast.collection.impl.queue.operations
- 
Store items' id as set when ClearOperation run. 
- ClearBackupOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.ClearBackupOperation
-  
- ClearBackupOperation(String, Set<Long>) - Constructor for class com.hazelcast.collection.impl.queue.operations.ClearBackupOperation
-  
- ClearBackupOperation - Class in com.hazelcast.map.impl.operation
-  
- ClearBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.ClearBackupOperation
-  
- ClearBackupOperation(String) - Constructor for class com.hazelcast.map.impl.operation.ClearBackupOperation
-  
- ClearBackupOperation - Class in com.hazelcast.multimap.impl.operations
-  
- ClearBackupOperation() - Constructor for class com.hazelcast.multimap.impl.operations.ClearBackupOperation
-  
- ClearBackupOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.ClearBackupOperation
-  
- clearBit(byte, int) - Static method in class com.hazelcast.nio.Bits
- 
Clears n-th bit of the byte value 
- clearBit(int, int) - Static method in class com.hazelcast.nio.Bits
- 
Clears n-th bit of the integer value 
- clearClients() - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
-  
- ClearExpiredOperation - Class in com.hazelcast.map.impl.operation
- 
Clear expired records. 
- ClearExpiredOperation(int) - Constructor for class com.hazelcast.map.impl.operation.ClearExpiredOperation
-  
- clearIndexes() - Method in class com.hazelcast.query.impl.Indexes
-  
- clearLocal(String) - Method in class com.hazelcast.map.impl.nearcache.AbstractNearCacheInvalidator
-  
- clearLockStore(int, ObjectNamespace) - Method in interface com.hazelcast.concurrent.lock.LockService
-  
- clearLockStore(int, ObjectNamespace) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-  
- clearMapOnly() - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
- 
This method clears the map.It does not invoke deleteAll on any associated MapStore. 
- clearNearCache(String) - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCacheManager
-  
- clearNearCache(String) - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheManager
- 
Clears  NearCache instance associated with given  name
 but not removes it. 
- clearNearCache(boolean) - Method in class com.hazelcast.map.impl.operation.MapOperation
-  
- ClearNearCacheOperation - Class in com.hazelcast.map.impl.operation
-  
- ClearNearCacheOperation() - Constructor for class com.hazelcast.map.impl.operation.ClearNearCacheOperation
-  
- ClearNearCacheOperation(String) - Constructor for class com.hazelcast.map.impl.operation.ClearNearCacheOperation
-  
- ClearOperation - Class in com.hazelcast.collection.impl.queue.operations
- 
Clears items stored by Queue. 
- ClearOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.ClearOperation
-  
- ClearOperation(String) - Constructor for class com.hazelcast.collection.impl.queue.operations.ClearOperation
-  
- ClearOperation - Class in com.hazelcast.map.impl.operation
-  
- ClearOperation() - Constructor for class com.hazelcast.map.impl.operation.ClearOperation
-  
- ClearOperation(String) - Constructor for class com.hazelcast.map.impl.operation.ClearOperation
-  
- ClearOperation - Class in com.hazelcast.multimap.impl.operations
-  
- ClearOperation() - Constructor for class com.hazelcast.multimap.impl.operations.ClearOperation
-  
- ClearOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.ClearOperation
-  
- ClearOperation - Class in com.hazelcast.replicatedmap.impl.operation
- 
- ClearOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ClearOperation
-  
- ClearOperation(String, boolean) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ClearOperation
-  
- ClearOperationFactory - Class in com.hazelcast.map.impl.operation
-  
- ClearOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.ClearOperationFactory
-  
- ClearOperationFactory(String) - Constructor for class com.hazelcast.map.impl.operation.ClearOperationFactory
-  
- ClearOperationFactory - Class in com.hazelcast.replicatedmap.impl.operation
-  
- ClearOperationFactory() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ClearOperationFactory
-  
- ClearOperationFactory(String) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ClearOperationFactory
-  
- clearPartition(boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- clearPartition(boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
- 
Clears internal partition data. 
- clearPartitionData(int) - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- clearPartitionReplica(int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- clearPartitionReplica(int) - Method in class com.hazelcast.collection.impl.collection.CollectionService
-  
- clearPartitionReplica(int) - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- clearPartitionReplica(int) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-  
- clearPartitionReplica(int) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-  
- clearPartitionReplica(int) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-  
- clearPartitionReplica(int) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-  
- clearPartitionReplica(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-  
- clearPartitionReplica(int) - Method in class com.hazelcast.map.impl.MapService
-  
- clearPartitionReplica(int) - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- clearPartitionReplica(int) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- clearPartitionReplica(int) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-  
- clearPartitionReplica(int) - Method in interface com.hazelcast.spi.MigrationAwareService
-  
- clearPartitionReplica(int) - Method in class com.hazelcast.transaction.impl.xa.XAService
-  
- clearPartitionReplicaVersions(int) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- clearPartitionReplicaVersions(int) - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- clearPartitions(boolean) - Method in interface com.hazelcast.map.impl.MapServiceContext
- 
Clears all partition based data allocated by MapService. 
- clearRecords() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- ClearRemoteTransactionBackupOperation - Class in com.hazelcast.transaction.impl.xa.operations
-  
- ClearRemoteTransactionBackupOperation() - Constructor for class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionBackupOperation
-  
- ClearRemoteTransactionBackupOperation(Data) - Constructor for class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionBackupOperation
-  
- ClearRemoteTransactionOperation - Class in com.hazelcast.transaction.impl.xa.operations
-  
- ClearRemoteTransactionOperation() - Constructor for class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
-  
- ClearRemoteTransactionOperation(Data) - Constructor for class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
-  
- ClearRemoteTransactionRequest - Class in com.hazelcast.transaction.client
-  
- ClearRemoteTransactionRequest() - Constructor for class com.hazelcast.transaction.client.ClearRemoteTransactionRequest
-  
- ClearRemoteTransactionRequest(Data) - Constructor for class com.hazelcast.transaction.client.ClearRemoteTransactionRequest
-  
- ClearRequest - Class in com.hazelcast.collection.impl.queue.client
- 
- ClearRequest() - Constructor for class com.hazelcast.collection.impl.queue.client.ClearRequest
-  
- ClearRequest(String) - Constructor for class com.hazelcast.collection.impl.queue.client.ClearRequest
-  
- ClearRequest - Class in com.hazelcast.multimap.impl.client
-  
- ClearRequest() - Constructor for class com.hazelcast.multimap.impl.client.ClearRequest
-  
- ClearRequest(String) - Constructor for class com.hazelcast.multimap.impl.client.ClearRequest
-  
- clearServers() - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
-  
- clearSystemProperty() - Method in enum com.hazelcast.client.config.ClientProperty
-  
- clearSystemProperty() - Method in enum com.hazelcast.instance.GroupProperty
-  
- clearSystemProperty() - Method in interface com.hazelcast.instance.HazelcastProperty
- 
Clears the environmental value of the property. 
- client - Variable in class com.hazelcast.client.impl.DefaultClientExtension
-  
- client - Variable in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- client - Variable in class com.hazelcast.client.spi.impl.ClusterListenerSupport
-  
- client - Variable in class com.hazelcast.client.spi.impl.listener.ClientListenerServiceImpl
-  
- Client - Interface in com.hazelcast.core
- 
The Client interface allows to get information about
 a connected client's socket address, type and uuid. 
- CLIENT_BINARY - Static variable in class com.hazelcast.nio.Protocols
- 
Protocol that is used for clients(java, c++ , c# client) 
- CLIENT_BINARY_NEW - Static variable in class com.hazelcast.nio.Protocols
- 
New Client Protocol that is used for clients(java, c++ , c# client) 
- CLIENT_CANCELLATION_REQUEST - Static variable in class com.hazelcast.mapreduce.impl.MapReducePortableHook
-  
- CLIENT_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- CLIENT_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- CLIENT_ERROR - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
-  
- CLIENT_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
- 
Name of the client executor. 
- CLIENT_JOB_PROCESS_INFO_REQUEST - Static variable in class com.hazelcast.mapreduce.impl.MapReducePortableHook
-  
- CLIENT_MAP_REDUCE_REQUEST - Static variable in class com.hazelcast.mapreduce.impl.MapReducePortableHook
-  
- CLIENT_PING - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-  
- CLIENT_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- CLIENT_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- CLIENT_RESPONSE - Static variable in class com.hazelcast.client.impl.ClientDataSerializerHook
- 
ClientResponse Class ID 
- CLIENT_TXN_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- CLIENT_TXN_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- ClientAddressCancellableDelegatingFuture<V> - Class in com.hazelcast.client.util
-  
- ClientAddressCancellableDelegatingFuture(ClientInvocationFuture, ClientContext, String, Address, V, ClientMessageDecoder) - Constructor for class com.hazelcast.client.util.ClientAddressCancellableDelegatingFuture
-  
- ClientAtomicLongProxy - Class in com.hazelcast.client.proxy
-  
- ClientAtomicLongProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientAtomicLongProxy
-  
- ClientAtomicReferenceProxy<E> - Class in com.hazelcast.client.proxy
-  
- ClientAtomicReferenceProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-  
- clientAwareService - Variable in class com.hazelcast.map.impl.MapService
-  
- ClientAwareService - Interface in com.hazelcast.spi
- 
A interface that can be implemented by a SPI Service so that it can be notified about client disconnects. 
- ClientAwsConfig - Class in com.hazelcast.client.config
- 
The AWSConfig contains the configuration for client
 to connect to nodes in aws environment. 
- ClientAwsConfig() - Constructor for class com.hazelcast.client.config.ClientAwsConfig
-  
- ClientCacheDistributedObject - Class in com.hazelcast.client.cache.impl
- 
Basic client proxy object which serves as an accessor to  ClientContext. 
- ClientCacheDistributedObject(String, String) - Constructor for class com.hazelcast.client.cache.impl.ClientCacheDistributedObject
-  
- ClientCacheProxy<K,V> - Class in com.hazelcast.client.cache.impl
- 
ICache implementation for client
  
 This proxy is the implementation of ICache and javax.cache.Cache which is returned by
 HazelcastClientCacheManager. 
- ClientCacheProxy(CacheConfig<K, V>, ClientContext, HazelcastClientCacheManager) - Constructor for class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- ClientCacheStatisticsImpl - Class in com.hazelcast.client.cache.impl
- 
- ClientCacheStatisticsImpl(long) - Constructor for class com.hazelcast.client.cache.impl.ClientCacheStatisticsImpl
-  
- ClientCacheStatisticsImpl(long, NearCacheStats) - Constructor for class com.hazelcast.client.cache.impl.ClientCacheStatisticsImpl
-  
- ClientCancellableDelegatingFuture<V> - Class in com.hazelcast.client.util
- 
An Abstract DelegatingFuture that can cancel a Runnable/Callable that is executed by an
  IExecutorService. 
- ClientCancellableDelegatingFuture(ClientInvocationFuture, ClientContext, String, V, ClientMessageDecoder) - Constructor for class com.hazelcast.client.util.ClientCancellableDelegatingFuture
-  
- ClientCancellationRequest - Class in com.hazelcast.mapreduce.impl.client
- 
This class is used to request a map reduce job cancellation on the job owning
 node from the emitting client. 
- ClientCancellationRequest() - Constructor for class com.hazelcast.mapreduce.impl.client.ClientCancellationRequest
-  
- ClientCancellationRequest(String, String) - Constructor for class com.hazelcast.mapreduce.impl.client.ClientCancellationRequest
-  
- ClientClusterProxy - Class in com.hazelcast.client.proxy
- 
Client implementation of the  Cluster. 
- ClientClusterProxy(ClientClusterServiceImpl) - Constructor for class com.hazelcast.client.proxy.ClientClusterProxy
-  
- ClientClusterService - Interface in com.hazelcast.client.spi
-  
- ClientClusterServiceImpl - Class in com.hazelcast.client.spi.impl
- 
- ClientClusterServiceImpl(HazelcastClientInstanceImpl, Collection<AddressProvider>) - Constructor for class com.hazelcast.client.spi.impl.ClientClusterServiceImpl
-  
- ClientClusterWideIterator<K,V> - Class in com.hazelcast.client.cache.impl
- 
Client side cluster-wide iterator for  ICache. 
- ClientClusterWideIterator(ClientCacheProxy<K, V>, ClientContext) - Constructor for class com.hazelcast.client.cache.impl.ClientClusterWideIterator
-  
- ClientConditionProxy - Class in com.hazelcast.client.proxy
-  
- ClientConditionProxy(ClientLockProxy, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientConditionProxy
-  
- ClientConfig - Class in com.hazelcast.client.config
- 
Main configuration to setup a Hazelcast Client 
- ClientConfig() - Constructor for class com.hazelcast.client.config.ClientConfig
-  
- clientConnected(Client) - Method in interface com.hazelcast.core.ClientListener
- 
Invoked when a new client is connected. 
- ClientConnection - Class in com.hazelcast.client.connection.nio
-  
- ClientConnection(HazelcastClientInstanceImpl, NonBlockingIOThread, NonBlockingIOThread, int, SocketChannelWrapper) - Constructor for class com.hazelcast.client.connection.nio.ClientConnection
-  
- ClientConnection(HazelcastClientInstanceImpl, int) - Constructor for class com.hazelcast.client.connection.nio.ClientConnection
-  
- clientConnectionCount - Variable in class com.hazelcast.internal.management.dto.ConnectionManagerDTO
-  
- ClientConnectionManager - Interface in com.hazelcast.client.connection
- 
- ClientConnectionManagerFactory - Interface in com.hazelcast.client.impl
-  
- ClientConnectionManagerImpl - Class in com.hazelcast.client.connection.nio
-  
- ClientConnectionManagerImpl(HazelcastClientInstanceImpl, AddressTranslator) - Constructor for class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-  
- ClientConsoleApp - Class in com.hazelcast.client.console
- 
A demo application to demonstrate a Hazelcast client. 
- ClientConsoleApp(HazelcastInstance) - Constructor for class com.hazelcast.client.console.ClientConsoleApp
-  
- ClientContext - Class in com.hazelcast.client.spi
-  
- ClientCountDownLatchProxy - Class in com.hazelcast.client.proxy
-  
- ClientCountDownLatchProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientCountDownLatchProxy
-  
- ClientCreateRequest - Class in com.hazelcast.client.impl.client
-  
- ClientCreateRequest() - Constructor for class com.hazelcast.client.impl.client.ClientCreateRequest
-  
- ClientCreateRequest(String, String, Address) - Constructor for class com.hazelcast.client.impl.client.ClientCreateRequest
-  
- ClientDataSerializerHook - Class in com.hazelcast.client.impl
- 
Client DataSerializable Factory ID 
- ClientDataSerializerHook() - Constructor for class com.hazelcast.client.impl.ClientDataSerializerHook
-  
- ClientDelegatingFuture<V> - Class in com.hazelcast.client.util
- 
Client Delegating Future is used to delegate ClientInvocationFuture to user to be used with
 andThen or get. 
- ClientDelegatingFuture(ClientInvocationFuture, SerializationService, ClientMessageDecoder, V) - Constructor for class com.hazelcast.client.util.ClientDelegatingFuture
-  
- ClientDelegatingFuture(ClientInvocationFuture, SerializationService, ClientMessageDecoder) - Constructor for class com.hazelcast.client.util.ClientDelegatingFuture
-  
- ClientDestroyRequest - Class in com.hazelcast.client.impl.client
-  
- ClientDestroyRequest() - Constructor for class com.hazelcast.client.impl.client.ClientDestroyRequest
-  
- ClientDestroyRequest(String, String) - Constructor for class com.hazelcast.client.impl.client.ClientDestroyRequest
-  
- clientDisconnected(String) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-  
- clientDisconnected(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-  
- clientDisconnected(Client) - Method in interface com.hazelcast.core.ClientListener
- 
Invoked when a new client is disconnected. 
- clientDisconnected(String) - Method in class com.hazelcast.map.impl.MapService
-  
- clientDisconnected(String) - Method in interface com.hazelcast.spi.ClientAwareService
- 
Invoked when a client disconnects from a member. 
- clientDisconnected(String) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-  
- ClientDisconnectionOperation - Class in com.hazelcast.client.impl.operations
-  
- ClientDisconnectionOperation() - Constructor for class com.hazelcast.client.impl.operations.ClientDisconnectionOperation
-  
- ClientDisconnectionOperation(String) - Constructor for class com.hazelcast.client.impl.operations.ClientDisconnectionOperation
-  
- ClientEndpoint - Interface in com.hazelcast.client
- 
Represents an endpoint to a client. 
- ClientEndPointDTO - Class in com.hazelcast.internal.management.dto
- 
- ClientEndPointDTO() - Constructor for class com.hazelcast.internal.management.dto.ClientEndPointDTO
-  
- ClientEndPointDTO(Client) - Constructor for class com.hazelcast.internal.management.dto.ClientEndPointDTO
-  
- ClientEndpointImpl - Class in com.hazelcast.client.impl
- 
- ClientEndpointImpl(ClientEngineImpl, Connection) - Constructor for class com.hazelcast.client.impl.ClientEndpointImpl
-  
- ClientEndpointManager - Interface in com.hazelcast.client
- 
- ClientEndpointManagerImpl - Class in com.hazelcast.client.impl
- 
- ClientEndpointManagerImpl(ClientEngineImpl, NodeEngine) - Constructor for class com.hazelcast.client.impl.ClientEndpointManagerImpl
-  
- ClientEngine - Interface in com.hazelcast.client
- 
The client Engine. 
- clientEngine - Variable in class com.hazelcast.client.impl.client.ClientRequest
-  
- clientEngine - Variable in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-  
- clientEngine - Variable in class com.hazelcast.instance.Node
-  
- ClientEngineImpl - Class in com.hazelcast.client.impl
- 
Class that requests, listeners from client handled in node side. 
- ClientEngineImpl(Node) - Constructor for class com.hazelcast.client.impl.ClientEngineImpl
-  
- ClientEngineImpl.ClientPacketProcessor - Class in com.hazelcast.client.impl
-  
- ClientEngineMBean - Class in com.hazelcast.jmx
- 
- ClientEngineMBean(HazelcastInstance, ClientEngine, ManagementService) - Constructor for class com.hazelcast.jmx.ClientEngineMBean
-  
- ClientEvent - Class in com.hazelcast.client
- 
Event used for notification of client connection and disconnection 
- ClientEvent(String, ClientEventType, InetSocketAddress, ClientType) - Constructor for class com.hazelcast.client.ClientEvent
-  
- ClientEventRegistration - Class in com.hazelcast.client.spi.impl.listener
- 
Keeps the information related to to an event registration made by clients 
- ClientEventRegistration(String, long, Address, ListenerMessageCodec) - Constructor for class com.hazelcast.client.spi.impl.listener.ClientEventRegistration
-  
- ClientEventType - Enum in com.hazelcast.client
- 
Event type used for client connection and disconnect events 
- ClientExceptionConverter - Interface in com.hazelcast.client.impl.exceptionconverters
- 
The ClientExceptionConverter is responsible for converting a Java Throwable to something a client can understand. 
- ClientExceptionConverters - Class in com.hazelcast.client.impl.exceptionconverters
- 
A utility class for getting the correct converter based on the client type. 
- ClientExceptionFactory - Class in com.hazelcast.client.impl.protocol
- 
This class has the error codes and means of
 1) creating exception from error code
 2) getting the error code of given exception 
- ClientExceptionFactory(boolean) - Constructor for class com.hazelcast.client.impl.protocol.ClientExceptionFactory
-  
- ClientExecutionService - Interface in com.hazelcast.client.spi
-  
- ClientExecutionServiceImpl - Class in com.hazelcast.client.spi.impl
-  
- ClientExecutionServiceImpl(String, ThreadGroup, ClassLoader, ClientProperties, int) - Constructor for class com.hazelcast.client.spi.impl.ClientExecutionServiceImpl
-  
- ClientExecutorServiceProxy - Class in com.hazelcast.client.proxy
-  
- ClientExecutorServiceProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- ClientExtension - Interface in com.hazelcast.client
- 
- ClientHeapNearCache<K> - Class in com.hazelcast.client.map.impl.nearcache
- 
- ClientHeapNearCache(String, ClientContext, NearCacheConfig) - Constructor for class com.hazelcast.client.map.impl.nearcache.ClientHeapNearCache
-  
- ClientHeartbeatMonitor - Class in com.hazelcast.client.impl
- 
Monitors client heartbeats.. 
- ClientHeartbeatMonitor(ClientEndpointManagerImpl, ClientEngine, ExecutionService, GroupProperties) - Constructor for class com.hazelcast.client.impl.ClientHeartbeatMonitor
-  
- ClientIdGeneratorProxy - Class in com.hazelcast.client.proxy
-  
- ClientIdGeneratorProxy(String, String, IAtomicLong) - Constructor for class com.hazelcast.client.proxy.ClientIdGeneratorProxy
-  
- ClientImpl - Class in com.hazelcast.client.impl
- 
Default  Client implementation. 
- ClientImpl(String, InetSocketAddress) - Constructor for class com.hazelcast.client.impl.ClientImpl
-  
- ClientInitialMembershipEvent - Class in com.hazelcast.cluster.client
-  
- ClientInitialMembershipEvent() - Constructor for class com.hazelcast.cluster.client.ClientInitialMembershipEvent
-  
- ClientInitialMembershipEvent(Member, int) - Constructor for class com.hazelcast.cluster.client.ClientInitialMembershipEvent
-  
- ClientInitialMembershipEvent(Member, MemberAttributeChange) - Constructor for class com.hazelcast.cluster.client.ClientInitialMembershipEvent
-  
- ClientInitialMembershipEvent(Collection<MemberImpl>) - Constructor for class com.hazelcast.cluster.client.ClientInitialMembershipEvent
-  
- ClientInvocation - Class in com.hazelcast.client.spi.impl
- 
ClientInvocation handles routing of a request from client
  
 1) Where should request be send
 2) Should it be retried
 3) How many times it is retried 
- ClientInvocation(HazelcastClientInstanceImpl, ClientMessage, int, Address, Connection) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocation
-  
- ClientInvocation(HazelcastClientInstanceImpl, ClientMessage) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocation
-  
- ClientInvocation(HazelcastClientInstanceImpl, ClientMessage, int) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocation
-  
- ClientInvocation(HazelcastClientInstanceImpl, ClientMessage, Address) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocation
-  
- ClientInvocation(HazelcastClientInstanceImpl, ClientMessage, Connection) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocation
-  
- clientInvocationFuture - Variable in class com.hazelcast.client.spi.impl.ClientInvocation
-  
- ClientInvocationFuture - Class in com.hazelcast.client.spi.impl
-  
- ClientInvocationFuture(ClientInvocation, HazelcastClientInstanceImpl, ClientMessage) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocationFuture
-  
- ClientInvocationService - Interface in com.hazelcast.client.spi
-  
- ClientJobProcessInformationRequest - Class in com.hazelcast.mapreduce.impl.client
- 
This class is used to retrieve current processed records and other statistics from
 emitting client to the job owning node. 
- ClientJobProcessInformationRequest() - Constructor for class com.hazelcast.mapreduce.impl.client.ClientJobProcessInformationRequest
-  
- ClientJobProcessInformationRequest(String, String) - Constructor for class com.hazelcast.mapreduce.impl.client.ClientJobProcessInformationRequest
-  
- ClientLifecycleListener - Class in com.hazelcast.web.listener
- 
Listens Lifecycle Events for client instance, if client is in shutdown state
  ClusteredSessionService is notified with failed connection 
- ClientLifecycleListener(ClusteredSessionService) - Constructor for class com.hazelcast.web.listener.ClientLifecycleListener
-  
- ClientListener - Interface in com.hazelcast.core
- 
The ClientListener provides the ability to listen to clients connecting and disconnecting from the cluster. 
- ClientListenerService - Interface in com.hazelcast.client.spi
- 
Client service to add/remove remote listeners. 
- ClientListenerServiceImpl - Class in com.hazelcast.client.spi.impl.listener
-  
- ClientListenerServiceImpl(HazelcastClientInstanceImpl, int, int) - Constructor for class com.hazelcast.client.spi.impl.listener.ClientListenerServiceImpl
-  
- ClientListProxy<E> - Class in com.hazelcast.client.proxy
-  
- ClientListProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientListProxy
-  
- ClientLockProxy - Class in com.hazelcast.client.proxy
-  
- ClientLockProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientLockProxy
-  
- ClientMapListener - Class in com.hazelcast.map.impl.client
-  
- ClientMapListener(ClientEndpoint, long) - Constructor for class com.hazelcast.map.impl.client.ClientMapListener
-  
- ClientMapProxy<K,V> - Class in com.hazelcast.client.proxy
-  
- ClientMapProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientMapProxy
-  
- ClientMapReduceProxy - Class in com.hazelcast.client.proxy
-  
- ClientMapReduceProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientMapReduceProxy
-  
- ClientMapReduceRequest<KeyIn,ValueIn> - Class in com.hazelcast.mapreduce.impl.client
- 
This class is used to prepare and start a map reduce job emitted by a client
 on a random node in the cluster (making it the job owner). 
- ClientMapReduceRequest() - Constructor for class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-  
- ClientMapReduceRequest(String, String, Collection, KeyPredicate, Mapper, CombinerFactory, ReducerFactory, KeyValueSource, int, TopologyChangedStrategy) - Constructor for class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-  
- ClientMembershipEvent - Class in com.hazelcast.cluster.client
-  
- ClientMembershipEvent() - Constructor for class com.hazelcast.cluster.client.ClientMembershipEvent
-  
- ClientMembershipEvent(Member, int) - Constructor for class com.hazelcast.cluster.client.ClientMembershipEvent
-  
- ClientMembershipEvent(Member, MemberAttributeChange) - Constructor for class com.hazelcast.cluster.client.ClientMembershipEvent
-  
- ClientMessage - Class in com.hazelcast.client.impl.protocol
- 
 Client Message is the carrier framed data as defined below. 
- ClientMessage() - Constructor for class com.hazelcast.client.impl.protocol.ClientMessage
-  
- clientMessage - Variable in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-  
- clientMessage - Variable in class com.hazelcast.client.spi.impl.ClientInvocationFuture
-  
- ClientMessageBuilder - Class in com.hazelcast.client.impl.protocol.util
- 
- ClientMessageBuilder(ClientMessageBuilder.MessageHandler) - Constructor for class com.hazelcast.client.impl.protocol.util.ClientMessageBuilder
-  
- ClientMessageBuilder.MessageHandler - Interface in com.hazelcast.client.impl.protocol.util
- 
Implementers will be responsible to delegate the constructed message 
- ClientMessageDecoder - Interface in com.hazelcast.client.impl
- 
Interface to pass specific decode methods to generic data structures that is dealing with client message 
- ClientMultiMapProxy<K,V> - Class in com.hazelcast.client.proxy
-  
- ClientMultiMapProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientMultiMapProxy
-  
- ClientNearCacheType - Enum in com.hazelcast.client.map.impl.nearcache
- 
Legal near cache types 
- ClientNetworkConfig - Class in com.hazelcast.client.config
- 
Contains configuration parameters for client network related behaviour 
- ClientNetworkConfig() - Constructor for class com.hazelcast.client.config.ClientNetworkConfig
-  
- ClientNonBlockingOutputThread - Class in com.hazelcast.client.connection.nio
-  
- ClientNonBlockingOutputThread(ThreadGroup, String, ILogger, NonBlockingIOThreadOutOfMemoryHandler) - Constructor for class com.hazelcast.client.connection.nio.ClientNonBlockingOutputThread
-  
- ClientNonSmartInvocationServiceImpl - Class in com.hazelcast.client.spi.impl
-  
- ClientNonSmartInvocationServiceImpl(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.spi.impl.ClientNonSmartInvocationServiceImpl
-  
- ClientNonSmartListenerService - Class in com.hazelcast.client.spi.impl.listener
-  
- ClientNonSmartListenerService(HazelcastClientInstanceImpl, int, int) - Constructor for class com.hazelcast.client.spi.impl.listener.ClientNonSmartListenerService
-  
- ClientOutOfMemoryHandler - Class in com.hazelcast.client
- 
To clear resources of the client upon OutOfMemory 
- ClientOutOfMemoryHandler() - Constructor for class com.hazelcast.client.ClientOutOfMemoryHandler
-  
- ClientPartitionCancellableDelegatingFuture<T> - Class in com.hazelcast.client.util
-  
- ClientPartitionCancellableDelegatingFuture(ClientInvocationFuture, ClientContext, String, int, T, ClientMessageDecoder) - Constructor for class com.hazelcast.client.util.ClientPartitionCancellableDelegatingFuture
-  
- ClientPartitionService - Interface in com.hazelcast.client.spi
-  
- ClientPartitionServiceImpl - Class in com.hazelcast.client.spi.impl
- 
- ClientPartitionServiceImpl(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.spi.impl.ClientPartitionServiceImpl
-  
- ClientPingRequest - Class in com.hazelcast.cluster.client
-  
- ClientPingRequest() - Constructor for class com.hazelcast.cluster.client.ClientPingRequest
-  
- ClientPortableFactory - Class in com.hazelcast.client.impl.client
- 
Factory class for central client request 
- ClientPortableFactory() - Constructor for class com.hazelcast.client.impl.client.ClientPortableFactory
-  
- ClientPortableHook - Class in com.hazelcast.client.impl.client
- 
Portable that creates a lot of the client related Portable instances. 
- ClientPortableHook() - Constructor for class com.hazelcast.client.impl.client.ClientPortableHook
-  
- ClientPrincipal - Class in com.hazelcast.client.impl.client
-  
- ClientPrincipal() - Constructor for class com.hazelcast.client.impl.client.ClientPrincipal
-  
- ClientPrincipal(String, String) - Constructor for class com.hazelcast.client.impl.client.ClientPrincipal
-  
- ClientProperties - Class in com.hazelcast.client.config
- 
Container for configured Hazelcast Client properties ( ClientProperty). 
- ClientProperties(ClientConfig) - Constructor for class com.hazelcast.client.config.ClientProperties
- 
Creates a container with configured Hazelcast properties. 
- ClientProperty - Enum in com.hazelcast.client.config
- 
Defines the name and default value for Hazelcast Client properties. 
- ClientProtocolBuffer - Interface in com.hazelcast.client.impl.protocol.util
- 
Interface for buffer to be used in client protocol. 
- ClientProtocolErrorCodes - Class in com.hazelcast.client.impl.protocol
- 
Each exception that are defined in client protocol have unique identifier which are error code. 
- ClientProxy - Class in com.hazelcast.client.spi
-  
- ClientProxy(String, String) - Constructor for class com.hazelcast.client.spi.ClientProxy
-  
- ClientProxyFactory - Interface in com.hazelcast.client.spi
-  
- ClientQueueProxy<E> - Class in com.hazelcast.client.proxy
-  
- ClientQueueProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientQueueProxy
-  
- ClientReadHandler - Class in com.hazelcast.client.connection.nio
-  
- ClientReadHandler(ClientConnection, NonBlockingIOThread, int) - Constructor for class com.hazelcast.client.connection.nio.ClientReadHandler
-  
- ClientReAuthOperation - Class in com.hazelcast.client.impl.operations
-  
- ClientReAuthOperation() - Constructor for class com.hazelcast.client.impl.operations.ClientReAuthOperation
-  
- ClientReAuthOperation(String) - Constructor for class com.hazelcast.client.impl.operations.ClientReAuthOperation
-  
- ClientRegistrationKey - Class in com.hazelcast.client.spi.impl.listener
-  
- ClientRegistrationKey(String, EventHandler, ListenerMessageCodec) - Constructor for class com.hazelcast.client.spi.impl.listener.ClientRegistrationKey
-  
- ClientRegistrationKey(String) - Constructor for class com.hazelcast.client.spi.impl.listener.ClientRegistrationKey
-  
- ClientReliableTopicConfig - Class in com.hazelcast.client.config
-  
- ClientReliableTopicConfig(String) - Constructor for class com.hazelcast.client.config.ClientReliableTopicConfig
- 
Creates a new ReliableTopicConfig with default settings. 
- ClientReliableTopicProxy<E> - Class in com.hazelcast.client.proxy
-  
- ClientReliableTopicProxy(String, HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.proxy.ClientReliableTopicProxy
-  
- ClientReplicatedMapAddEntryListenerRequest - Class in com.hazelcast.replicatedmap.impl.client
- 
- ClientReplicatedMapAddEntryListenerRequest(String, Predicate, Data) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
-  
- ClientReplicatedMapAddNearCacheListenerRequest - Class in com.hazelcast.replicatedmap.impl.client
- 
Internal Request to add listener to replicated map to invalidate near cache from client 
- ClientReplicatedMapAddNearCacheListenerRequest() - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddNearCacheListenerRequest
-  
- ClientReplicatedMapAddNearCacheListenerRequest(String) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddNearCacheListenerRequest
-  
- ClientReplicatedMapClearRequest - Class in com.hazelcast.replicatedmap.impl.client
- 
- ClientReplicatedMapClearRequest(String) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapClearRequest
-  
- ClientReplicatedMapContainsKeyRequest - Class in com.hazelcast.replicatedmap.impl.client
- 
- ClientReplicatedMapContainsKeyRequest(String, Data) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsKeyRequest
-  
- ClientReplicatedMapContainsValueRequest - Class in com.hazelcast.replicatedmap.impl.client
- 
- ClientReplicatedMapContainsValueRequest(String, Data, int) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsValueRequest
-  
- ClientReplicatedMapEntrySetRequest - Class in com.hazelcast.replicatedmap.impl.client
- 
- ClientReplicatedMapEntrySetRequest(String, int) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapEntrySetRequest
-  
- ClientReplicatedMapGetRequest - Class in com.hazelcast.replicatedmap.impl.client
- 
- ClientReplicatedMapGetRequest(String, Data) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapGetRequest
-  
- ClientReplicatedMapIsEmptyRequest - Class in com.hazelcast.replicatedmap.impl.client
- 
- ClientReplicatedMapIsEmptyRequest(String, int) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapIsEmptyRequest
-  
- ClientReplicatedMapKeySetRequest - Class in com.hazelcast.replicatedmap.impl.client
- 
- ClientReplicatedMapKeySetRequest(String, int) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapKeySetRequest
-  
- ClientReplicatedMapProxy<K,V> - Class in com.hazelcast.client.proxy
- 
The replicated map client side proxy implementation proxying all requests to a member node 
- ClientReplicatedMapProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-  
- ClientReplicatedMapPutAllRequest - Class in com.hazelcast.replicatedmap.impl.client
- 
- ClientReplicatedMapPutAllRequest() - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-  
- ClientReplicatedMapPutAllRequest(String, ReplicatedMapEntries) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-  
- ClientReplicatedMapPutTtlRequest - Class in com.hazelcast.replicatedmap.impl.client
- 
- ClientReplicatedMapPutTtlRequest() - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutTtlRequest
-  
- ClientReplicatedMapPutTtlRequest(String, Data, Data, long) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutTtlRequest
-  
- ClientReplicatedMapRemoveEntryListenerRequest - Class in com.hazelcast.replicatedmap.impl.client
- 
- ClientReplicatedMapRemoveEntryListenerRequest() - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-  
- ClientReplicatedMapRemoveEntryListenerRequest(String) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-  
- ClientReplicatedMapRemoveRequest - Class in com.hazelcast.replicatedmap.impl.client
- 
- ClientReplicatedMapRemoveRequest() - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveRequest
-  
- ClientReplicatedMapRemoveRequest(String, Data) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveRequest
-  
- ClientReplicatedMapSizeRequest - Class in com.hazelcast.replicatedmap.impl.client
- 
Client request class for  Map.size() implementation 
- ClientReplicatedMapSizeRequest(String, int) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapSizeRequest
-  
- ClientReplicatedMapValuesRequest - Class in com.hazelcast.replicatedmap.impl.client
- 
- ClientReplicatedMapValuesRequest(String, int) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapValuesRequest
-  
- ClientRequest - Class in com.hazelcast.client.impl.client
-  
- ClientRequest() - Constructor for class com.hazelcast.client.impl.client.ClientRequest
-  
- ClientResponse - Class in com.hazelcast.client.impl.client
-  
- ClientResponse() - Constructor for class com.hazelcast.client.impl.client.ClientResponse
-  
- ClientResponse(Data, long, boolean) - Constructor for class com.hazelcast.client.impl.client.ClientResponse
-  
- ClientRingbufferProxy<E> - Class in com.hazelcast.client.proxy
-  
- ClientRingbufferProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientRingbufferProxy
-  
- ClientSecurityConfig - Class in com.hazelcast.client.config
- 
Contains the security configuration for a client. 
- ClientSecurityConfig() - Constructor for class com.hazelcast.client.config.ClientSecurityConfig
-  
- ClientSemaphoreProxy - Class in com.hazelcast.client.proxy
-  
- ClientSemaphoreProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientSemaphoreProxy
-  
- clientSerializationVersion - Variable in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
-  
- ClientService - Interface in com.hazelcast.core
- 
ClientService allows you to query connected  Clients and
 attach/detach  ClientListeners to listen to connection events. 
- ClientServiceProxy - Class in com.hazelcast.client.impl
- 
- ClientServiceProxy(Node) - Constructor for class com.hazelcast.client.impl.ClientServiceProxy
-  
- ClientSetProxy<E> - Class in com.hazelcast.client.proxy
-  
- ClientSetProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientSetProxy
-  
- ClientSmartInvocationServiceImpl - Class in com.hazelcast.client.spi.impl
-  
- ClientSmartInvocationServiceImpl(HazelcastClientInstanceImpl, LoadBalancer) - Constructor for class com.hazelcast.client.spi.impl.ClientSmartInvocationServiceImpl
-  
- ClientSmartListenerService - Class in com.hazelcast.client.spi.impl.listener
-  
- ClientSmartListenerService(HazelcastClientInstanceImpl, int, int) - Constructor for class com.hazelcast.client.spi.impl.listener.ClientSmartListenerService
-  
- clientThreadId - Variable in class com.hazelcast.transaction.client.BaseTransactionRequest
-  
- ClientTopicProxy<E> - Class in com.hazelcast.client.proxy
-  
- ClientTopicProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientTopicProxy
-  
- ClientTransactionContext - Interface in com.hazelcast.client.spi
- 
Provides a context to perform transactional operations: beginning/committing transactions, but also retrieving
 transactional data-structures like the  TransactionalMap. 
- ClientTransactionManagerService - Interface in com.hazelcast.client.spi
-  
- ClientTransactionManagerServiceImpl - Class in com.hazelcast.client.spi.impl
-  
- ClientTransactionManagerServiceImpl(HazelcastClientInstanceImpl, LoadBalancer) - Constructor for class com.hazelcast.client.spi.impl.ClientTransactionManagerServiceImpl
-  
- ClientTxnListProxy<E> - Class in com.hazelcast.client.proxy.txn
-  
- ClientTxnListProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.proxy.txn.ClientTxnListProxy
-  
- ClientTxnListProxy<E> - Class in com.hazelcast.client.txn.proxy
-  
- ClientTxnListProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.txn.proxy.ClientTxnListProxy
-  
- ClientTxnMapProxy<K,V> - Class in com.hazelcast.client.proxy.txn
- 
- ClientTxnMapProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-  
- ClientTxnMapProxy<K,V> - Class in com.hazelcast.client.txn.proxy
- 
- ClientTxnMapProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.txn.proxy.ClientTxnMapProxy
-  
- ClientTxnMultiMapProxy<K,V> - Class in com.hazelcast.client.proxy.txn
-  
- ClientTxnMultiMapProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.proxy.txn.ClientTxnMultiMapProxy
-  
- ClientTxnMultiMapProxy<K,V> - Class in com.hazelcast.client.txn.proxy
-  
- ClientTxnMultiMapProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.txn.proxy.ClientTxnMultiMapProxy
-  
- ClientTxnPortableHook - Class in com.hazelcast.transaction.client
- 
Factory class for client transaction related classes 
- ClientTxnPortableHook() - Constructor for class com.hazelcast.transaction.client.ClientTxnPortableHook
-  
- ClientTxnQueueProxy<E> - Class in com.hazelcast.client.proxy.txn
-  
- ClientTxnQueueProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.proxy.txn.ClientTxnQueueProxy
-  
- ClientTxnQueueProxy<E> - Class in com.hazelcast.client.txn.proxy
-  
- ClientTxnQueueProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.txn.proxy.ClientTxnQueueProxy
-  
- ClientTxnSetProxy<E> - Class in com.hazelcast.client.proxy.txn
-  
- ClientTxnSetProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.proxy.txn.ClientTxnSetProxy
-  
- ClientTxnSetProxy<E> - Class in com.hazelcast.client.txn.proxy
-  
- ClientTxnSetProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.txn.proxy.ClientTxnSetProxy
-  
- ClientType - Enum in com.hazelcast.core
- 
Type of a client. 
- clientType - Variable in class com.hazelcast.internal.management.dto.ClientEndPointDTO
-  
- ClientTypes - Class in com.hazelcast.client
- 
Constants class that contains the different types of clients. 
- ClientWriteHandler - Class in com.hazelcast.client.connection.nio
-  
- ClientWriteHandler(ClientConnection, NonBlockingIOThread, int) - Constructor for class com.hazelcast.client.connection.nio.ClientWriteHandler
-  
- Clock - Class in com.hazelcast.util
- 
Utility class to be able to simulate different time zones. 
- Clock.ClockImpl - Class in com.hazelcast.util
- 
Clock abstraction to be able to simulate different clocks
 without changing actual system time. 
- Clock.ClockImpl() - Constructor for class com.hazelcast.util.Clock.ClockImpl
-  
- clone() - Method in class com.hazelcast.monitor.TimedMemberState
-  
- clone() - Method in class com.hazelcast.util.collection.InflatableSet
- 
Returns a shallow copy of this InflatableSet instance: the keys and
 values themselves are not cloned. 
- close() - Method in class com.hazelcast.cache.HazelcastCachingProvider
-  
- close(ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
-  
- close(URI, ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
-  
- close(boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- close() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- close() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-  
- close(ClassLoader) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-  
- close(URI, ClassLoader) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-  
- close(boolean) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Close is equivalent to below operations in the given order:
 
     close resources.
     unregister all listeners.
  
- close() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- close(Throwable) - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- close() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- close() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
-  
- close() - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- close() - Method in class com.hazelcast.mapreduce.impl.ListKeyValueSource
-  
- close() - Method in class com.hazelcast.mapreduce.impl.MapKeyValueSource
-  
- close() - Method in class com.hazelcast.mapreduce.impl.MultiMapKeyValueSource
-  
- close() - Method in class com.hazelcast.mapreduce.impl.SetKeyValueSource
-  
- close() - Method in interface com.hazelcast.nio.Connection
- 
Closes this connection. 
- close() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-  
- close() - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-  
- close() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- close(Throwable) - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- close(EventRegistration) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-  
- close(EventRegistration) - Method in interface com.hazelcast.spi.impl.eventservice.InternalEventService
- 
Closes an EventRegistration. 
- close() - Method in class com.hazelcast.util.ContextMutexFactory.Mutex
-  
- closeableListeners - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-  
- closeConnection() - Method in class com.hazelcast.nio.ascii.TextReadHandler
-  
- closeInbound() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-  
- closeInbound() - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
- 
Closes inbound. 
- closeListeners() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- closeOutbound() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-  
- closeOutbound() - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
- 
Closes outbound. 
- closeResource(Closeable) - Static method in class com.hazelcast.nio.IOUtil
- 
Closes the Closable quietly. 
- closeSegments(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- CloudyUtility - Class in com.hazelcast.aws.utility
-  
- Cluster - Interface in com.hazelcast.core
- 
Hazelcast cluster interface. 
- CLUSTER - Static variable in class com.hazelcast.nio.Protocols
- 
Protocol that is used among nodes 
- ClusterAuthenticator - Class in com.hazelcast.client.impl
- 
Used to authenticate client connections to cluster as parameter to ClientConnectionManager. 
- ClusterAuthenticator(HazelcastClientInstanceImpl, Credentials) - Constructor for class com.hazelcast.client.impl.ClusterAuthenticator
-  
- ClusterClock - Interface in com.hazelcast.cluster
-  
- ClusterClockImpl - Class in com.hazelcast.cluster.impl
-  
- ClusterClockImpl(ILogger) - Constructor for class com.hazelcast.cluster.impl.ClusterClockImpl
-  
- ClusterDataSerializerHook - Class in com.hazelcast.cluster.impl
-  
- ClusterDataSerializerHook() - Constructor for class com.hazelcast.cluster.impl.ClusterDataSerializerHook
-  
- ClusterDataSerializerHook.ClusterDataSerializerFactoryImpl - Class in com.hazelcast.cluster.impl
-  
- ClusterDataSerializerHook.ClusterDataSerializerFactoryImpl() - Constructor for class com.hazelcast.cluster.impl.ClusterDataSerializerHook.ClusterDataSerializerFactoryImpl
-  
- ClusteredSessionService - Class in com.hazelcast.web
- 
ClusteredSessionService is a proxy class which delegates all
 operations on distributed map to hazelcast cluster used for session
 replication. 
- ClusteredSessionService(FilterConfig, Properties, String) - Constructor for class com.hazelcast.web.ClusteredSessionService
- 
Instantiates a new Clustered session service. 
- ClusterHeartbeatManager - Class in com.hazelcast.cluster.impl
- 
ClusterHeartbeatManager manages the heartbeat sending and receiving
 process of a node. 
- ClusterHeartbeatManager(Node, ClusterServiceImpl) - Constructor for class com.hazelcast.cluster.impl.ClusterHeartbeatManager
-  
- clusterJoinManager - Variable in class com.hazelcast.cluster.impl.AbstractJoiner
-  
- ClusterJoinManager - Class in com.hazelcast.cluster.impl
- 
ClusterJoinManager manages member join process. 
- ClusterJoinManager(Node, ClusterServiceImpl, Lock) - Constructor for class com.hazelcast.cluster.impl.ClusterJoinManager
-  
- ClusterListenerSupport - Class in com.hazelcast.client.spi.impl
-  
- ClusterListenerSupport(HazelcastClientInstanceImpl, Collection<AddressProvider>) - Constructor for class com.hazelcast.client.spi.impl.ClusterListenerSupport
-  
- ClusterPermission - Class in com.hazelcast.security.permission
-  
- ClusterPermission(String) - Constructor for class com.hazelcast.security.permission.ClusterPermission
-  
- ClusterPermissionCollection - Class in com.hazelcast.security.permission
-  
- ClusterPermissionCollection() - Constructor for class com.hazelcast.security.permission.ClusterPermissionCollection
-  
- ClusterPermissionCollection(Class<? extends Permission>) - Constructor for class com.hazelcast.security.permission.ClusterPermissionCollection
-  
- ClusterPropsRequest - Class in com.hazelcast.internal.management.request
- 
Request for cluster properties. 
- ClusterPropsRequest() - Constructor for class com.hazelcast.internal.management.request.ClusterPropsRequest
-  
- ClusterService - Interface in com.hazelcast.cluster
- 
A service responsible for member related functionality. 
- clusterService - Variable in class com.hazelcast.cluster.impl.AbstractJoiner
-  
- clusterService - Variable in class com.hazelcast.instance.Node
-  
- clusterService - Variable in class com.hazelcast.map.impl.LocalMapStatsProvider
-  
- clusterService - Variable in class com.hazelcast.map.impl.nearcache.AbstractNearCacheInvalidator
-  
- clusterService - Variable in class com.hazelcast.map.impl.query.MapQueryEngineImpl
-  
- ClusterServiceImpl - Class in com.hazelcast.cluster.impl
-  
- ClusterServiceImpl(Node) - Constructor for class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- ClusterState - Enum in com.hazelcast.cluster
- 
ClusterStateconsists several states of the cluster
 which each state can allow and/or deny specific actions
 and/or change behaviours of specific actions.
 
- ClusterStateManager - Class in com.hazelcast.cluster.impl
- 
ClusterStateManager stores cluster state and manages cluster state transactions. 
- ClusterStateTransactionLogRecord - Class in com.hazelcast.cluster.impl
- 
TransactionLogRecord implementation to be used in ClusterStatetransactions.
 
- ClusterStateTransactionLogRecord() - Constructor for class com.hazelcast.cluster.impl.ClusterStateTransactionLogRecord
-  
- ClusterStateTransactionLogRecord(ClusterState, Address, Address, String, long, int) - Constructor for class com.hazelcast.cluster.impl.ClusterStateTransactionLogRecord
-  
- ClusterWideIterator<K,V> - Class in com.hazelcast.cache.impl
- 
Cluster-wide iterator for  ICache. 
- ClusterWideIterator(CacheProxy<K, V>) - Constructor for class com.hazelcast.cache.impl.ClusterWideIterator
-  
- clusterWideUpdateManagementCenterUrl(String, String, String) - Method in class com.hazelcast.internal.management.ManagementCenterService
-  
- CoalescingDelayedTrigger - Class in com.hazelcast.util.scheduler
- 
Coalescing trigger can be used when you want coalesce multiple execution of  Runnable. 
- CoalescingDelayedTrigger(ExecutionService, long, long, Runnable) - Constructor for class com.hazelcast.util.scheduler.CoalescingDelayedTrigger
-  
- collate(Iterable<ValueIn>) - Method in interface com.hazelcast.mapreduce.Collator
- 
This method is called with the mapped and possibly reduced values from the MapReduce algorithm. 
- Collator<ValueIn,ValueOut> - Interface in com.hazelcast.mapreduce
- 
This interface can be implemented to define a Collator which is executed after calculation
 of the MapReduce algorithm on remote cluster nodes but before returning the final result.
 Collator can, for example, be used to sum up a final value.
 
- COLLECT_XA - Static variable in class com.hazelcast.transaction.client.ClientTxnPortableHook
-  
- COLLECTION - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
-  
- COLLECTION - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
-  
- COLLECTION_ADD - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_ADD - Static variable in class com.hazelcast.collection.impl.collection.CollectionPortableHook
-  
- COLLECTION_ADD_ALL - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_ADD_ALL - Static variable in class com.hazelcast.collection.impl.collection.CollectionPortableHook
-  
- COLLECTION_ADD_ALL_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_ADD_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_ADD_LISTENER - Static variable in class com.hazelcast.collection.impl.collection.CollectionPortableHook
-  
- COLLECTION_CLEAR - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_CLEAR - Static variable in class com.hazelcast.collection.impl.collection.CollectionPortableHook
-  
- COLLECTION_CLEAR_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_COMPARE_AND_REMOVE - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_COMPARE_AND_REMOVE - Static variable in class com.hazelcast.collection.impl.collection.CollectionPortableHook
-  
- COLLECTION_CONTAINS - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_CONTAINS - Static variable in class com.hazelcast.collection.impl.collection.CollectionPortableHook
-  
- COLLECTION_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- COLLECTION_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- COLLECTION_EVENT - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_EVENT_FILTER - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_GET_ALL - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_GET_ALL - Static variable in class com.hazelcast.collection.impl.collection.CollectionPortableHook
-  
- COLLECTION_IS_EMPTY - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_IS_EMPTY - Static variable in class com.hazelcast.collection.impl.collection.CollectionPortableHook
-  
- COLLECTION_ITEM - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- COLLECTION_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- COLLECTION_PREPARE - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_PREPARE_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_REMOVE - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_REMOVE - Static variable in class com.hazelcast.collection.impl.collection.CollectionPortableHook
-  
- COLLECTION_REMOVE_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_REMOVE_LISTENER - Static variable in class com.hazelcast.collection.impl.collection.CollectionPortableHook
-  
- COLLECTION_RESERVE_ADD - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_RESERVE_REMOVE - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_ROLLBACK - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_ROLLBACK_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_SIZE - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_SIZE - Static variable in class com.hazelcast.collection.impl.collection.CollectionPortableHook
-  
- COLLECTION_TXN_ADD - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_TXN_ADD_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_TXN_REMOVE - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- COLLECTION_TXN_REMOVE_BACKUP - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- CollectionAddAllBackupOperation - Class in com.hazelcast.collection.impl.collection.operations
-  
- CollectionAddAllBackupOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionAddAllBackupOperation
-  
- CollectionAddAllBackupOperation(String, Map<Long, Data>) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionAddAllBackupOperation
-  
- CollectionAddAllOperation - Class in com.hazelcast.collection.impl.collection.operations
-  
- CollectionAddAllOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
-  
- CollectionAddAllOperation(String, List<Data>) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
-  
- CollectionAddAllRequest - Class in com.hazelcast.collection.impl.collection.client
-  
- CollectionAddAllRequest() - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionAddAllRequest
-  
- CollectionAddAllRequest(String, List<Data>) - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionAddAllRequest
-  
- CollectionAddBackupOperation - Class in com.hazelcast.collection.impl.collection.operations
-  
- CollectionAddBackupOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionAddBackupOperation
-  
- CollectionAddBackupOperation(String, long, Data) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionAddBackupOperation
-  
- CollectionAddListenerRequest - Class in com.hazelcast.collection.impl.collection.client
- 
this class is used to attach a listener to node for collections 
- CollectionAddListenerRequest() - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionAddListenerRequest
-  
- CollectionAddListenerRequest(String, boolean) - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionAddListenerRequest
-  
- CollectionAddOperation - Class in com.hazelcast.collection.impl.collection.operations
-  
- CollectionAddOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
-  
- CollectionAddOperation(String, Data) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
-  
- CollectionAddRequest - Class in com.hazelcast.collection.impl.collection.client
-  
- CollectionAddRequest() - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionAddRequest
-  
- CollectionAddRequest(String, Data) - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionAddRequest
-  
- CollectionBackupAwareOperation - Class in com.hazelcast.collection.impl.collection.operations
-  
- CollectionBackupAwareOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionBackupAwareOperation
-  
- CollectionBackupAwareOperation(String) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionBackupAwareOperation
-  
- CollectionClearBackupOperation - Class in com.hazelcast.collection.impl.collection.operations
-  
- CollectionClearBackupOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionClearBackupOperation
-  
- CollectionClearBackupOperation(String, Set<Long>) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionClearBackupOperation
-  
- CollectionClearOperation - Class in com.hazelcast.collection.impl.collection.operations
-  
- CollectionClearOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionClearOperation
-  
- CollectionClearOperation(String) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionClearOperation
-  
- CollectionClearRequest - Class in com.hazelcast.collection.impl.collection.client
-  
- CollectionClearRequest() - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionClearRequest
-  
- CollectionClearRequest(String) - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionClearRequest
-  
- CollectionCompareAndRemoveOperation - Class in com.hazelcast.collection.impl.collection.operations
-  
- CollectionCompareAndRemoveOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionCompareAndRemoveOperation
-  
- CollectionCompareAndRemoveOperation(String, boolean, Set<Data>) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionCompareAndRemoveOperation
-  
- CollectionCompareAndRemoveRequest - Class in com.hazelcast.collection.impl.collection.client
-  
- CollectionCompareAndRemoveRequest() - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionCompareAndRemoveRequest
-  
- CollectionCompareAndRemoveRequest(String, Set<Data>, boolean) - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionCompareAndRemoveRequest
-  
- CollectionConfig<T extends CollectionConfig> - Class in com.hazelcast.config
- 
Provides configuration service for Collection. 
- CollectionConfig() - Constructor for class com.hazelcast.config.CollectionConfig
-  
- CollectionConfig(CollectionConfig) - Constructor for class com.hazelcast.config.CollectionConfig
-  
- CollectionContainer - Class in com.hazelcast.collection.impl.collection
-  
- CollectionContainer() - Constructor for class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- CollectionContainer(String, NodeEngine) - Constructor for class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- CollectionContainsOperation - Class in com.hazelcast.collection.impl.collection.operations
-  
- CollectionContainsOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionContainsOperation
-  
- CollectionContainsOperation(String, Set<Data>) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionContainsOperation
-  
- CollectionContainsRequest - Class in com.hazelcast.collection.impl.collection.client
-  
- CollectionContainsRequest() - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionContainsRequest
-  
- CollectionContainsRequest(String, Set<Data>) - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionContainsRequest
-  
- CollectionContainsRequest(String, Data) - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionContainsRequest
-  
- CollectionDataSerializerHook - Class in com.hazelcast.collection.impl.collection
-  
- CollectionDataSerializerHook() - Constructor for class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- CollectionEvent - Class in com.hazelcast.collection.impl.collection
-  
- CollectionEvent() - Constructor for class com.hazelcast.collection.impl.collection.CollectionEvent
-  
- CollectionEvent(String, Data, ItemEventType, Address) - Constructor for class com.hazelcast.collection.impl.collection.CollectionEvent
-  
- CollectionEventFilter - Class in com.hazelcast.collection.impl.collection
-  
- CollectionEventFilter() - Constructor for class com.hazelcast.collection.impl.collection.CollectionEventFilter
-  
- CollectionEventFilter(boolean) - Constructor for class com.hazelcast.collection.impl.collection.CollectionEventFilter
-  
- CollectionGetAllOperation - Class in com.hazelcast.collection.impl.collection.operations
-  
- CollectionGetAllOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionGetAllOperation
-  
- CollectionGetAllOperation(String) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionGetAllOperation
-  
- CollectionGetAllRequest - Class in com.hazelcast.collection.impl.collection.client
-  
- CollectionGetAllRequest() - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionGetAllRequest
-  
- CollectionGetAllRequest(String) - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionGetAllRequest
-  
- CollectionIsEmptyOperation - Class in com.hazelcast.collection.impl.collection.operations
-  
- CollectionIsEmptyOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionIsEmptyOperation
-  
- CollectionIsEmptyOperation(String) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionIsEmptyOperation
-  
- CollectionIsEmptyRequest - Class in com.hazelcast.collection.impl.collection.client
-  
- CollectionIsEmptyRequest() - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionIsEmptyRequest
-  
- CollectionIsEmptyRequest(String) - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionIsEmptyRequest
-  
- CollectionItem - Class in com.hazelcast.collection.impl.collection
-  
- CollectionItem() - Constructor for class com.hazelcast.collection.impl.collection.CollectionItem
-  
- CollectionItem(long, Data) - Constructor for class com.hazelcast.collection.impl.collection.CollectionItem
-  
- CollectionOperation - Class in com.hazelcast.collection.impl.collection.operations
-  
- CollectionOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionOperation
-  
- CollectionOperation(String) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionOperation
-  
- CollectionPortableHook - Class in com.hazelcast.collection.impl.collection
-  
- CollectionPortableHook() - Constructor for class com.hazelcast.collection.impl.collection.CollectionPortableHook
-  
- CollectionPrepareBackupOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-  
- CollectionPrepareBackupOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareBackupOperation
-  
- CollectionPrepareBackupOperation(String, long, String, boolean) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareBackupOperation
-  
- CollectionPrepareOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-  
- CollectionPrepareOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareOperation
-  
- CollectionPrepareOperation(int, String, String, long, String, boolean) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareOperation
-  
- CollectionRegionAccessStrategyAdapter - Class in com.hazelcast.hibernate.region
- 
Simple adapter implementation for transactional / concurrent access control on collections 
- CollectionRegionAccessStrategyAdapter(AccessDelegate<? extends HazelcastCollectionRegion>) - Constructor for class com.hazelcast.hibernate.region.CollectionRegionAccessStrategyAdapter
-  
- CollectionRemoveBackupOperation - Class in com.hazelcast.collection.impl.collection.operations
-  
- CollectionRemoveBackupOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionRemoveBackupOperation
-  
- CollectionRemoveBackupOperation(String, long) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionRemoveBackupOperation
-  
- CollectionRemoveListenerRequest - Class in com.hazelcast.collection.impl.collection.client
-  
- CollectionRemoveListenerRequest() - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionRemoveListenerRequest
-  
- CollectionRemoveListenerRequest(String, String) - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionRemoveListenerRequest
-  
- CollectionRemoveOperation - Class in com.hazelcast.collection.impl.collection.operations
-  
- CollectionRemoveOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionRemoveOperation
-  
- CollectionRemoveOperation(String, Data) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionRemoveOperation
-  
- CollectionRemoveRequest - Class in com.hazelcast.collection.impl.collection.client
-  
- CollectionRemoveRequest() - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionRemoveRequest
-  
- CollectionRemoveRequest(String, Data) - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionRemoveRequest
-  
- CollectionReplicationOperation - Class in com.hazelcast.collection.impl.collection.operations
-  
- CollectionReplicationOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionReplicationOperation
-  
- CollectionReplicationOperation(Map<String, CollectionContainer>, int, int) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionReplicationOperation
-  
- CollectionRequest - Class in com.hazelcast.collection.impl.collection.client
-  
- CollectionRequest() - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionRequest
-  
- CollectionRequest(String) - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionRequest
-  
- CollectionReserveAddOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-  
- CollectionReserveAddOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveAddOperation
-  
- CollectionReserveAddOperation(String, String, Data) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveAddOperation
-  
- CollectionReserveRemoveOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-  
- CollectionReserveRemoveOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveRemoveOperation
-  
- CollectionReserveRemoveOperation(String, long, Data, String) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveRemoveOperation
-  
- CollectionRollbackBackupOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-  
- CollectionRollbackBackupOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackBackupOperation
-  
- CollectionRollbackBackupOperation(String, long, boolean) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackBackupOperation
-  
- CollectionRollbackOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-  
- CollectionRollbackOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackOperation
-  
- CollectionRollbackOperation(int, String, String, long, boolean) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackOperation
-  
- CollectionService - Class in com.hazelcast.collection.impl.collection
-  
- CollectionService(NodeEngine) - Constructor for class com.hazelcast.collection.impl.collection.CollectionService
-  
- CollectionSizeOperation - Class in com.hazelcast.collection.impl.collection.operations
-  
- CollectionSizeOperation() - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionSizeOperation
-  
- CollectionSizeOperation(String) - Constructor for class com.hazelcast.collection.impl.collection.operations.CollectionSizeOperation
-  
- CollectionSizeRequest - Class in com.hazelcast.collection.impl.collection.client
-  
- CollectionSizeRequest() - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionSizeRequest
-  
- CollectionSizeRequest(String) - Constructor for class com.hazelcast.collection.impl.collection.client.CollectionSizeRequest
-  
- CollectionTransactionLogRecord - Class in com.hazelcast.collection.impl.txncollection
-  
- CollectionTransactionLogRecord() - Constructor for class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
-  
- CollectionTransactionLogRecord(long, String, int, String, String, Operation) - Constructor for class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
-  
- CollectionTransactionRollbackOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-  
- CollectionTransactionRollbackOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTransactionRollbackOperation
-  
- CollectionTransactionRollbackOperation(String, String) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTransactionRollbackOperation
-  
- CollectionTxnAddBackupOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-  
- CollectionTxnAddBackupOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddBackupOperation
-  
- CollectionTxnAddBackupOperation(String, long, Data) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddBackupOperation
-  
- CollectionTxnAddOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-  
- CollectionTxnAddOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddOperation
-  
- CollectionTxnAddOperation(String, long, Data) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddOperation
-  
- CollectionTxnRemoveBackupOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-  
- CollectionTxnRemoveBackupOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveBackupOperation
-  
- CollectionTxnRemoveBackupOperation(String, long) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveBackupOperation
-  
- CollectionTxnRemoveOperation - Class in com.hazelcast.collection.impl.txncollection.operations
-  
- CollectionTxnRemoveOperation() - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveOperation
-  
- CollectionTxnRemoveOperation(String, long) - Constructor for class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveOperation
-  
- CollectionUtil - Class in com.hazelcast.util
- 
Various collection utility methods, mainly targeted to use internally. 
- CollectRemoteTransactionsOperation - Class in com.hazelcast.transaction.impl.xa.operations
-  
- CollectRemoteTransactionsOperation() - Constructor for class com.hazelcast.transaction.impl.xa.operations.CollectRemoteTransactionsOperation
-  
- CollectRemoteTransactionsOperationFactory - Class in com.hazelcast.transaction.impl.xa.operations
-  
- CollectRemoteTransactionsOperationFactory() - Constructor for class com.hazelcast.transaction.impl.xa.operations.CollectRemoteTransactionsOperationFactory
-  
- CollectXATransactionsRequest - Class in com.hazelcast.transaction.client
-  
- CollectXATransactionsRequest() - Constructor for class com.hazelcast.transaction.client.CollectXATransactionsRequest
-  
- com.hazelcast - package com.hazelcast
-  
- com.hazelcast.aws - package com.hazelcast.aws
- 
Provides interfaces/classes for Hazelcast AWS. 
- com.hazelcast.aws.impl - package com.hazelcast.aws.impl
- 
Provides implementation classes for Hazelcast AWS. 
- com.hazelcast.aws.security - package com.hazelcast.aws.security
- 
Provides security classes for Hazelcast AWS. 
- com.hazelcast.aws.utility - package com.hazelcast.aws.utility
- 
Provides utility classes for Hazelcast AWS. 
- com.hazelcast.buildutils - package com.hazelcast.buildutils
- 
This module contains Maven and other build additions that are used by
 Hazelcast to build bundle modules 
- com.hazelcast.cache - package 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 - package com.hazelcast.cache.impl
- 
     Hazelcast JSR-107 aka JCache implementation 
- com.hazelcast.cache.impl.client - package com.hazelcast.cache.impl.client
- 
     Hazelcast JSR-107 aka JCache implementation
     Client Requests 
- com.hazelcast.cache.impl.event - package com.hazelcast.cache.impl.event
- 
     Event classes to define listenters for JCache other than EntryListener 
- com.hazelcast.cache.impl.maxsize - package com.hazelcast.cache.impl.maxsize
- 
     Max-Size policy interfaces for cache. 
- com.hazelcast.cache.impl.maxsize.impl - package com.hazelcast.cache.impl.maxsize.impl
- 
     Max-Size policy implementations for cache. 
- com.hazelcast.cache.impl.merge - package com.hazelcast.cache.impl.merge
- 
This package contains merge functionality for Hazelcast cache.
 
 
- com.hazelcast.cache.impl.merge.entry - package com.hazelcast.cache.impl.merge.entry
- 
This package contains merge entry internal interfaces and functionality for Hazelcast cache.
 
 
- com.hazelcast.cache.impl.merge.policy - package com.hazelcast.cache.impl.merge.policy
- 
This package contains merge policy internal interfaces and functionality for Hazelcast cache.
 
 
- com.hazelcast.cache.impl.nearcache - package com.hazelcast.cache.impl.nearcache
- 
     Near cache support. 
- com.hazelcast.cache.impl.nearcache.impl - package com.hazelcast.cache.impl.nearcache.impl
- 
     Near cache implementations. 
- com.hazelcast.cache.impl.nearcache.impl.maxsize - package com.hazelcast.cache.impl.nearcache.impl.maxsize
- 
     Max-Size policy implementations for near-cache. 
- com.hazelcast.cache.impl.nearcache.impl.record - package com.hazelcast.cache.impl.nearcache.impl.record
- 
     Near cache record implementations. 
- com.hazelcast.cache.impl.nearcache.impl.store - package com.hazelcast.cache.impl.nearcache.impl.store
- 
     Near cache store implementations. 
- com.hazelcast.cache.impl.operation - package com.hazelcast.cache.impl.operation
- 
Hazelcast JSR-107 aka JCache implementation 
- com.hazelcast.cache.impl.record - package com.hazelcast.cache.impl.record
- 
     Hazelcast JSR-107 aka JCache implementation
     Internal record store 
- com.hazelcast.cache.merge - package com.hazelcast.cache.merge
- 
This package contains out of the box merge policies.
 
 
- com.hazelcast.client - package com.hazelcast.client
- 
Contains classes/interfaces related to Client 
- com.hazelcast.client.cache.impl - package com.hazelcast.client.cache.impl
- 
     Hazelcast JSR-107 aka JCache implementation client side 
- com.hazelcast.client.config - package com.hazelcast.client.config
- 
Contains classes related to config for com.hazelcast.client 
- com.hazelcast.client.connection - package com.hazelcast.client.connection
- 
Provides connection interfaces/classes for com.hazelcast.client 
- com.hazelcast.client.connection.nio - package com.hazelcast.client.connection.nio
- 
Contains classes related to New IO for com.hazelcast.client.connection 
- com.hazelcast.client.console - package com.hazelcast.client.console
- 
This package contains ClientConsoleApp
 
 
- com.hazelcast.client.impl - package com.hazelcast.client.impl
- 
Contains most of the client side HazelcastInstance implementation functionality. 
- com.hazelcast.client.impl.client - package com.hazelcast.client.impl.client
- 
This contains the Requests and other DTO's exchanged between client/server 
- com.hazelcast.client.impl.exceptionconverters - package com.hazelcast.client.impl.exceptionconverters
- 
Contains logic to convert client exceptions. 
- com.hazelcast.client.impl.operations - package com.hazelcast.client.impl.operations
- 
Contains client operations 
- com.hazelcast.client.impl.protocol - package com.hazelcast.client.impl.protocol
- 
Client protocol related private implementation classes 
- com.hazelcast.client.impl.protocol.exception - package com.hazelcast.client.impl.protocol.exception
-  
- com.hazelcast.client.impl.protocol.task - package com.hazelcast.client.impl.protocol.task
- 
Client tasks associated with requests. 
- com.hazelcast.client.impl.protocol.task.atomiclong - package com.hazelcast.client.impl.protocol.task.atomiclong
- 
Client protocol tasks implementations for AtomicLong 
- com.hazelcast.client.impl.protocol.task.atomicreference - package com.hazelcast.client.impl.protocol.task.atomicreference
- 
Client protocol tasks implementations for AtomicReference 
- com.hazelcast.client.impl.protocol.task.cache - package com.hazelcast.client.impl.protocol.task.cache
- 
Client protocol tasks implementations for JCache 
- com.hazelcast.client.impl.protocol.task.condition - package com.hazelcast.client.impl.protocol.task.condition
- 
Client protocol tasks implementations for Condition 
- com.hazelcast.client.impl.protocol.task.countdownlatch - package com.hazelcast.client.impl.protocol.task.countdownlatch
- 
Client protocol tasks implementations for CountDownLatch 
- com.hazelcast.client.impl.protocol.task.executorservice - package com.hazelcast.client.impl.protocol.task.executorservice
- 
Client protocol tasks implementations for ExecutorService 
- com.hazelcast.client.impl.protocol.task.list - package com.hazelcast.client.impl.protocol.task.list
- 
Client protocol tasks implementations for List 
- com.hazelcast.client.impl.protocol.task.lock - package com.hazelcast.client.impl.protocol.task.lock
- 
Client protocol tasks implementations for ILock 
- com.hazelcast.client.impl.protocol.task.map - package com.hazelcast.client.impl.protocol.task.map
- 
Client protocol tasks implementations for map 
- com.hazelcast.client.impl.protocol.task.mapreduce - package com.hazelcast.client.impl.protocol.task.mapreduce
- 
Client protocol tasks implementations for map reduce 
- com.hazelcast.client.impl.protocol.task.multimap - package com.hazelcast.client.impl.protocol.task.multimap
- 
Client protocol tasks implementations for multi map 
- com.hazelcast.client.impl.protocol.task.queue - package com.hazelcast.client.impl.protocol.task.queue
- 
Client protocol tasks implementations for Queue 
- com.hazelcast.client.impl.protocol.task.replicatedmap - package com.hazelcast.client.impl.protocol.task.replicatedmap
- 
Client protocol tasks implementations for ReplicatedMap 
- com.hazelcast.client.impl.protocol.task.ringbuffer - package com.hazelcast.client.impl.protocol.task.ringbuffer
- 
Client protocol tasks implementations for Ringbuffer 
- com.hazelcast.client.impl.protocol.task.semaphore - package com.hazelcast.client.impl.protocol.task.semaphore
- 
Client protocol tasks implementations for Semaphore 
- com.hazelcast.client.impl.protocol.task.set - package com.hazelcast.client.impl.protocol.task.set
- 
Client protocol tasks implementations for set 
- com.hazelcast.client.impl.protocol.task.topic - package com.hazelcast.client.impl.protocol.task.topic
- 
Client protocol tasks implementations for Topic 
- com.hazelcast.client.impl.protocol.task.transaction - package com.hazelcast.client.impl.protocol.task.transaction
- 
Client protocol tasks implementations for Transaction related 
- com.hazelcast.client.impl.protocol.task.transactionallist - package com.hazelcast.client.impl.protocol.task.transactionallist
- 
Client protocol tasks implementations for Transactional List 
- com.hazelcast.client.impl.protocol.task.transactionalmap - package com.hazelcast.client.impl.protocol.task.transactionalmap
- 
Client protocol tasks implementations for Transactional Map 
- com.hazelcast.client.impl.protocol.task.transactionalmultimap - package com.hazelcast.client.impl.protocol.task.transactionalmultimap
- 
Client protocol tasks implementations for Transactional MultiMap 
- com.hazelcast.client.impl.protocol.task.transactionalqueue - package com.hazelcast.client.impl.protocol.task.transactionalqueue
- 
Client protocol tasks implementations for Transactional Queue 
- com.hazelcast.client.impl.protocol.task.transactionalset - package com.hazelcast.client.impl.protocol.task.transactionalset
- 
Client protocol tasks implementations for Transactional Set 
- com.hazelcast.client.impl.protocol.util - package com.hazelcast.client.impl.protocol.util
- 
Protocol utils 
- com.hazelcast.client.map.impl.nearcache - package com.hazelcast.client.map.impl.nearcache
- 
Contains classes/interfaces related to com.hazelcast.client.map.impl.nearcache 
- com.hazelcast.client.proxy - package com.hazelcast.client.proxy
- 
This package contains client side proxy implementations of the different Hazelcast data structures
 and operation types 
- com.hazelcast.client.proxy.txn - package com.hazelcast.client.proxy.txn
- 
Contains classes related to proxy for client transactions 
- com.hazelcast.client.proxy.txn.xa - package com.hazelcast.client.proxy.txn.xa
- 
Contains classes related to proxy for XA 
- com.hazelcast.client.spi - package com.hazelcast.client.spi
- 
Contains classes/interfaces related to Service Provider Interface
 such as ClientProxy , ClientClusterService 
- com.hazelcast.client.spi.impl - package com.hazelcast.client.spi.impl
- 
Provides util classes for com.hazelcast.client 
- com.hazelcast.client.spi.impl.discovery - package com.hazelcast.client.spi.impl.discovery
-  
- com.hazelcast.client.spi.impl.listener - package com.hazelcast.client.spi.impl.listener
-  
- com.hazelcast.client.txn - package com.hazelcast.client.txn
- 
Contains classes related to Txn
 such as TransactionProxy 
- com.hazelcast.client.txn.proxy - package com.hazelcast.client.txn.proxy
- 
Contains classes related to proxy for com.hazelcast.client.client.txn 
- com.hazelcast.client.txn.proxy.xa - package com.hazelcast.client.txn.proxy.xa
- 
Contains classes related to proxy for XA 
- com.hazelcast.client.util - package com.hazelcast.client.util
- 
This package contains some utility classes and the base implementations of the
 loadbalancer implementations 
- com.hazelcast.cluster - package com.hazelcast.cluster
- 
This package contains the cluster functionality.
 
 
- com.hazelcast.cluster.client - package com.hazelcast.cluster.client
- 
This package contains the client cluster functionality.
 
 
- com.hazelcast.cluster.impl - package com.hazelcast.cluster.impl
- 
This package contains the implementation of the cluster functionality.
 
 
- com.hazelcast.cluster.impl.operations - package com.hazelcast.cluster.impl.operations
- 
This package contains operations for the com.hazelcast.cluster.impl package.
 
 
- com.hazelcast.cluster.memberselector - package com.hazelcast.cluster.memberselector
- 
- com.hazelcast.collection.common - package com.hazelcast.collection.common
- 
This package contains common classes related to all collections 
- com.hazelcast.collection.impl.collection - package com.hazelcast.collection.impl.collection
-  
- com.hazelcast.collection.impl.collection.client - package com.hazelcast.collection.impl.collection.client
-  
- com.hazelcast.collection.impl.collection.operations - package com.hazelcast.collection.impl.collection.operations
-  
- com.hazelcast.collection.impl.list - package com.hazelcast.collection.impl.list
- 
This package contains IList functionality for Hazelcast.
 
 
- com.hazelcast.collection.impl.list.client - package com.hazelcast.collection.impl.list.client
-  
- com.hazelcast.collection.impl.list.operations - package com.hazelcast.collection.impl.list.operations
-  
- com.hazelcast.collection.impl.queue - package com.hazelcast.collection.impl.queue
-  
- com.hazelcast.collection.impl.queue.client - package com.hazelcast.collection.impl.queue.client
- 
This package contains client requests for the IQueue.
 
 
- com.hazelcast.collection.impl.queue.operations - package com.hazelcast.collection.impl.queue.operations
- 
This package contains the IQueue operations
 
 
- com.hazelcast.collection.impl.set - package com.hazelcast.collection.impl.set
- 
This package contains ISet functionality for Hazelcast.
 
 
- com.hazelcast.collection.impl.set.operations - package com.hazelcast.collection.impl.set.operations
-  
- com.hazelcast.collection.impl.txncollection - package com.hazelcast.collection.impl.txncollection
-  
- com.hazelcast.collection.impl.txncollection.client - package com.hazelcast.collection.impl.txncollection.client
-  
- com.hazelcast.collection.impl.txncollection.operations - package com.hazelcast.collection.impl.txncollection.operations
-  
- com.hazelcast.collection.impl.txnlist - package com.hazelcast.collection.impl.txnlist
-  
- com.hazelcast.collection.impl.txnlist.client - package com.hazelcast.collection.impl.txnlist.client
-  
- com.hazelcast.collection.impl.txnqueue - package com.hazelcast.collection.impl.txnqueue
-  
- com.hazelcast.collection.impl.txnqueue.client - package com.hazelcast.collection.impl.txnqueue.client
-  
- com.hazelcast.collection.impl.txnqueue.operations - package com.hazelcast.collection.impl.txnqueue.operations
-  
- com.hazelcast.collection.impl.txnset - package com.hazelcast.collection.impl.txnset
-  
- com.hazelcast.collection.impl.txnset.client - package com.hazelcast.collection.impl.txnset.client
-  
- com.hazelcast.concurrent.atomiclong - package com.hazelcast.concurrent.atomiclong
- 
This package contains IAtomicLong functionality for Hazelcast. 
 The IAtomicLong is the distributed version of the  AtomicLong. 
- com.hazelcast.concurrent.atomiclong.client - package com.hazelcast.concurrent.atomiclong.client
- 
This package contains client requests for the IAtomicLong.
 This package contains all the client request object to operate on the
 IAtomicLong that are send by the client.
 
- com.hazelcast.concurrent.atomiclong.operations - package com.hazelcast.concurrent.atomiclong.operations
- 
This package contains the operations on the IAtomicLong.
 
 
- com.hazelcast.concurrent.atomicreference - package com.hazelcast.concurrent.atomicreference
- 
This package contains IAtomicReferece functionality for Hazelcast. 
 The IAtomicReference is the distributed version of the  AtomicReference. 
- com.hazelcast.concurrent.atomicreference.client - package com.hazelcast.concurrent.atomicreference.client
- 
This package contains client requests for the IAtomicLong.
 This package contains all the client request object to operate on the
 IAtomicLong that are send by the client.
 
- com.hazelcast.concurrent.atomicreference.operations - package com.hazelcast.concurrent.atomicreference.operations
- 
This package contains the operations on the IAtomicReference.
 
 
- com.hazelcast.concurrent.countdownlatch - package com.hazelcast.concurrent.countdownlatch
- 
This package contains ICountDownLatch functionality for Hazelcast. 
 The ICountDownLatch is the distributed version of the  CountDownLatch. 
- com.hazelcast.concurrent.countdownlatch.client - package com.hazelcast.concurrent.countdownlatch.client
- 
This package contains client requests for the ICountDownLatch.
 This package contains all the client requests object to operate on the
 ICountDownLatch that are send by the client.
 
- com.hazelcast.concurrent.countdownlatch.operations - package com.hazelcast.concurrent.countdownlatch.operations
- 
This package contains the operations on the ICountDownLatch.
 
 
- com.hazelcast.concurrent.idgen - package com.hazelcast.concurrent.idgen
- 
This package contains IdGenerator functionality for Hazelcast. 
 With the  IdGenerator it is very simple to create cluster wide id's. 
- com.hazelcast.concurrent.lock - package com.hazelcast.concurrent.lock
- 
This package contains Lock for Hazelcast. 
 The  ILock is the distributed version of the  Lock. 
- com.hazelcast.concurrent.lock.client - package com.hazelcast.concurrent.lock.client
- 
This package contains client requests for the ILock.
 This package contains all the client requests object to operate on the
 ILock that are send by the client.
 
- com.hazelcast.concurrent.lock.operations - package com.hazelcast.concurrent.lock.operations
- 
This package contains the operations on the ILock.
 
 
- com.hazelcast.concurrent.semaphore - package com.hazelcast.concurrent.semaphore
- 
This package contains ISemaphore functionality for Hazelcast. 
 The ISemaphore is the distributed version of the  Semaphore. 
- com.hazelcast.concurrent.semaphore.client - package com.hazelcast.concurrent.semaphore.client
- 
This package contains client requests for the ISemaphore.
 
 
- com.hazelcast.concurrent.semaphore.operations - package com.hazelcast.concurrent.semaphore.operations
- 
This package contains the operations on the ISemaphore.
 
 
- com.hazelcast.config - package com.hazelcast.config
- 
Provides classes for configuring HazelcastInstance. 
- com.hazelcast.config.matcher - package com.hazelcast.config.matcher
- 
- com.hazelcast.config.properties - package com.hazelcast.config.properties
- 
This package contains the public API for properties defined in the XML configuration. 
- com.hazelcast.console - package com.hazelcast.console
- 
This package contains classes related to ConsoleApp
 
 
- com.hazelcast.core - package com.hazelcast.core
- 
Provides core API interfaces/classes. 
- com.hazelcast.core.server - package com.hazelcast.core.server
- 
This package contains classes to launch standalone Hazelcast Instance
 
 
- com.hazelcast.executor.impl - package com.hazelcast.executor.impl
- 
This package contains IExecutorService functionality for Hazelcast. 
 The IExecutorService extends the  ExecutorService and provides all kinds
 of additional methods related to distributed systems. 
- com.hazelcast.executor.impl.client - package com.hazelcast.executor.impl.client
- 
This package contains client requests for the IExecutorService.
 
 
- com.hazelcast.executor.impl.operations - package com.hazelcast.executor.impl.operations
- 
This package contains operations for the IExecutorService.
 
 
- com.hazelcast.hibernate - package com.hazelcast.hibernate
- 
Contains interfaces/classes related to Hibernate. 
- com.hazelcast.hibernate.access - package com.hazelcast.hibernate.access
- 
Provides access interfaces/classes for Hibernate. 
- com.hazelcast.hibernate.distributed - package com.hazelcast.hibernate.distributed
- 
Provides distributed class for Hibernate. 
- com.hazelcast.hibernate.instance - package com.hazelcast.hibernate.instance
- 
Provides instance interfaces/classes for Hibernate. 
- com.hazelcast.hibernate.local - package com.hazelcast.hibernate.local
- 
Provides local classes for Hibernate. 
- com.hazelcast.hibernate.region - package com.hazelcast.hibernate.region
- 
Provides region interfaces/classes for Hibernate. 
- com.hazelcast.hibernate.serialization - package com.hazelcast.hibernate.serialization
- 
This class contains the Hibernate4 serializer hooks so what we don't
 loose handling on serialization while working on hibernate 
- com.hazelcast.instance - package com.hazelcast.instance
- 
This package contains Hazelcast Instance functionality.
 
 
- com.hazelcast.internal - package com.hazelcast.internal
- 
Contains the internal packages of Hazelcast. 
- com.hazelcast.internal.ascii - package com.hazelcast.internal.ascii
- 
This package contains Ascii functionality for Hazelcast.
 This is required for Memcached and the REST api.
 
- com.hazelcast.internal.ascii.memcache - package com.hazelcast.internal.ascii.memcache
- 
This package contains MemoryCache functionality for Hazelcast.
 
 
- com.hazelcast.internal.ascii.rest - package com.hazelcast.internal.ascii.rest
- 
This package contains Reset functionality for Hazelcast.
 
 
- com.hazelcast.internal.eviction - package com.hazelcast.internal.eviction
- 
     Eviction policy implementations for cache. 
- com.hazelcast.internal.eviction.impl - package com.hazelcast.internal.eviction.impl
- 
     Eviction implementations for cache. 
- com.hazelcast.internal.eviction.impl.evaluator - package com.hazelcast.internal.eviction.impl.evaluator
- 
- com.hazelcast.internal.eviction.impl.strategy - package com.hazelcast.internal.eviction.impl.strategy
- 
- com.hazelcast.internal.eviction.impl.strategy.sampling - package com.hazelcast.internal.eviction.impl.strategy.sampling
- 
- com.hazelcast.internal.management - package com.hazelcast.internal.management
- 
Contains classes to provide data/operation interface for Management Center. 
- com.hazelcast.internal.management.dto - package com.hazelcast.internal.management.dto
- 
These contain the DTO object to exchange information with the management center. 
- com.hazelcast.internal.management.operation - package com.hazelcast.internal.management.operation
- 
Contains operations that are called from Management Center. 
- com.hazelcast.internal.management.request - package com.hazelcast.internal.management.request
- 
Contains requests that made from Management Center. 
- com.hazelcast.internal.metrics - package com.hazelcast.internal.metrics
- 
Contains the Hazelcast Metrics. 
- com.hazelcast.internal.metrics.impl - package com.hazelcast.internal.metrics.impl
- 
- com.hazelcast.internal.metrics.metricsets - package com.hazelcast.internal.metrics.metricsets
- 
Contains all kinds of metric packs. 
- com.hazelcast.internal.metrics.renderers - package com.hazelcast.internal.metrics.renderers
- 
- com.hazelcast.internal.monitors - package com.hazelcast.internal.monitors
- 
Contains functionality what is happening in a HazelcastInstance. 
- com.hazelcast.internal.serialization - package com.hazelcast.internal.serialization
- 
Contains the private serialization API + implementation. 
- com.hazelcast.internal.serialization.impl - package com.hazelcast.internal.serialization.impl
-  
- com.hazelcast.internal.serialization.impl.bufferpool - package com.hazelcast.internal.serialization.impl.bufferpool
- 
Contains the logic for the BufferPool. 
- com.hazelcast.jca - package com.hazelcast.jca
- 
This package contains jca functionality 
- com.hazelcast.jclouds - package com.hazelcast.jclouds
- 
Provides interfaces/classes for Hazelcast JClouds Discovery Provider 
- com.hazelcast.jmx - package com.hazelcast.jmx
- 
Contains Hazelcast management bean classes. 
- com.hazelcast.jmx.suppliers - package com.hazelcast.jmx.suppliers
- 
Contains Hazelcast management bean stat providers. 
- com.hazelcast.logging - package com.hazelcast.logging
- 
This package contains logging functionality for Hazelcast.
 Since Hazelcast has a zero dependency policy, Hazelcast provides a logging abstraction like commongs logging,
 so that different logging frameworks like log4j, can be hooked in.
 
- com.hazelcast.map - package com.hazelcast.map
- 
Contains Hazelcast map module classes. 
- com.hazelcast.map.impl - package com.hazelcast.map.impl
- 
- com.hazelcast.map.impl.client - package com.hazelcast.map.impl.client
- 
Contains client requests for the  IMap
- com.hazelcast.map.impl.event - package com.hazelcast.map.impl.event
-  
- com.hazelcast.map.impl.eviction - package com.hazelcast.map.impl.eviction
- 
This package contains eviction classes.
 
 
- com.hazelcast.map.impl.mapstore - package com.hazelcast.map.impl.mapstore
- 
Contains map store operations. 
- com.hazelcast.map.impl.mapstore.writebehind - package com.hazelcast.map.impl.mapstore.writebehind
- 
Package for processing write behind store operations. 
- com.hazelcast.map.impl.mapstore.writebehind.entry - package com.hazelcast.map.impl.mapstore.writebehind.entry
-  
- com.hazelcast.map.impl.mapstore.writethrough - package com.hazelcast.map.impl.mapstore.writethrough
- 
Package for processing write through store operations. 
- com.hazelcast.map.impl.nearcache - package com.hazelcast.map.impl.nearcache
-  
- com.hazelcast.map.impl.operation - package com.hazelcast.map.impl.operation
- 
Package for map operations. 
- com.hazelcast.map.impl.proxy - package com.hazelcast.map.impl.proxy
- 
Contains map proxy implementation and support classes. 
- com.hazelcast.map.impl.query - package com.hazelcast.map.impl.query
-  
- com.hazelcast.map.impl.querycache.event - package com.hazelcast.map.impl.querycache.event
- 
This package contains classes for query cache events. 
- com.hazelcast.map.impl.querycache.event.sequence - package com.hazelcast.map.impl.querycache.event.sequence
- 
This package contains classes which are used to give sequence numbers to events. 
- com.hazelcast.map.impl.record - package com.hazelcast.map.impl.record
- 
Contains record specific classes. 
- com.hazelcast.map.impl.recordstore - package com.hazelcast.map.impl.recordstore
-  
- com.hazelcast.map.impl.tx - package com.hazelcast.map.impl.tx
- 
- com.hazelcast.map.impl.wan - package com.hazelcast.map.impl.wan
- 
Contains wan replication event classes 
- com.hazelcast.map.listener - package com.hazelcast.map.listener
- 
- com.hazelcast.map.merge - package com.hazelcast.map.merge
- 
Contains merge policies for  IMap
- com.hazelcast.mapreduce - package 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.aggregation - package com.hazelcast.mapreduce.aggregation
- 
This package contains the aggregation API and the convenience helper classes
 to retrieve predefined aggregation implementations. 
- com.hazelcast.mapreduce.aggregation.impl - package com.hazelcast.mapreduce.aggregation.impl
- 
This package contains a set of predefined aggregation implementations 
- com.hazelcast.mapreduce.impl - package com.hazelcast.mapreduce.impl
- 
This package contains the default implementation for the map reduce framework
 internals. 
- com.hazelcast.mapreduce.impl.client - package com.hazelcast.mapreduce.impl.client
- 
This package contains request and response classes for communication between cluster
 members and Hazelcast native clients 
- com.hazelcast.mapreduce.impl.notification - package com.hazelcast.mapreduce.impl.notification
- 
This package contains all remote node notifications 
- com.hazelcast.mapreduce.impl.operation - package com.hazelcast.mapreduce.impl.operation
- 
This package contains all remote operations that are needed to control work on
 supervising or worker nodes. 
- com.hazelcast.mapreduce.impl.task - package com.hazelcast.mapreduce.impl.task
- 
This package contains the base implementation for a standard map reduce job. 
- com.hazelcast.memory - package com.hazelcast.memory
- 
Provides classes/interfaces for memory utilities, heap/native memory storage support. 
- com.hazelcast.monitor - package com.hazelcast.monitor
- 
Contains Hazelcast statistics interfaces related to map, queue, topic, multimap, executor service etc. 
- com.hazelcast.monitor.impl - package com.hazelcast.monitor.impl
- 
Contains Hazelcast statistics implementations related to map, queue, topic, multimap, executor service etc. 
- com.hazelcast.multimap.impl - package com.hazelcast.multimap.impl
- 
Contains classes for Hazelcast MultiMap module. 
- com.hazelcast.multimap.impl.client - package com.hazelcast.multimap.impl.client
- 
Contains client requests for Hazelcast MultiMap module. 
- com.hazelcast.multimap.impl.operations - package com.hazelcast.multimap.impl.operations
- 
Contains operations for Hazelcast MultiMap module. 
- com.hazelcast.multimap.impl.txn - package com.hazelcast.multimap.impl.txn
- 
This package contains the Transaction behavior for the Multimap.
 
 
- com.hazelcast.nio - package com.hazelcast.nio
- 
This package contains classes related to New IO
 
 
- com.hazelcast.nio.ascii - package com.hazelcast.nio.ascii
- 
Contains SocketTextReader and SocketTextWriter classes; 
- com.hazelcast.nio.serialization - package com.hazelcast.nio.serialization
- 
Contains interfaces/classes related to serialization;
 such as serializer interfaces, input/output streams. 
- com.hazelcast.nio.ssl - package com.hazelcast.nio.ssl
- 
Contains interfaces/classes related to SSL for New IO 
- com.hazelcast.nio.tcp - package com.hazelcast.nio.tcp
- 
Contains functionality for the TCP/IP Networking between cluster members
 
 
- com.hazelcast.nio.tcp.nonblocking - package com.hazelcast.nio.tcp.nonblocking
- 
- com.hazelcast.nio.tcp.nonblocking.iobalancer - package com.hazelcast.nio.tcp.nonblocking.iobalancer
- 
Contains Handler Migration classes 
- com.hazelcast.nio.tcp.spinning - package com.hazelcast.nio.tcp.spinning
- 
- com.hazelcast.osgi - package com.hazelcast.osgi
- 
This package contains the OSGI functionality contract points for Hazelcast.
 
 
- com.hazelcast.osgi.impl - package com.hazelcast.osgi.impl
- 
This package contains the OSGI functionality implementations for Hazelcast.
 
 
- com.hazelcast.partition - package com.hazelcast.partition
- 
Contains the partition logic for Hazelcast. 
- com.hazelcast.partition.client - package com.hazelcast.partition.client
- 
Contains client functionality for partition related information. 
- com.hazelcast.partition.impl - package com.hazelcast.partition.impl
- 
- com.hazelcast.partition.membergroup - package com.hazelcast.partition.membergroup
- 
todo 
- com.hazelcast.partition.strategy - package com.hazelcast.partition.strategy
- 
Packages contains different partitioning strategies. 
- com.hazelcast.query - package com.hazelcast.query
- 
Contains interfaces/classes related to Hazelcast query and indexing support. 
- com.hazelcast.query.extractor - package com.hazelcast.query.extractor
- 
Contains classes related to custom attributes and the extraction of their values. 
- com.hazelcast.query.impl - package com.hazelcast.query.impl
- 
Contains the implementation classes of the query functionality. 
- com.hazelcast.query.impl.getters - package com.hazelcast.query.impl.getters
- 
Helper classes for extractions of values from object instances. 
- com.hazelcast.query.impl.predicates - package com.hazelcast.query.impl.predicates
-  
- com.hazelcast.quorum - package com.hazelcast.quorum
- 
Contains classes related to cluster quorum. 
- com.hazelcast.quorum.impl - package com.hazelcast.quorum.impl
- 
Contains cluster quorum implementation classes. 
- com.hazelcast.quorum.impl.operation - package com.hazelcast.quorum.impl.operation
- 
Contains cluster quorum operation classes. 
- com.hazelcast.replicatedmap - package com.hazelcast.replicatedmap
- 
Contains classes related to cluster quorum. 
- com.hazelcast.replicatedmap.impl - package com.hazelcast.replicatedmap.impl
- 
This package contains the implementation of the replicated map service itself and some connection interfaces only used
 internally. 
- com.hazelcast.replicatedmap.impl.client - package com.hazelcast.replicatedmap.impl.client
- 
This package contains classes for client communication on replicated map implementation 
- com.hazelcast.replicatedmap.impl.operation - package com.hazelcast.replicatedmap.impl.operation
- 
This package contains replicated map operations which are executed on remote nodes 
- com.hazelcast.replicatedmap.impl.record - package com.hazelcast.replicatedmap.impl.record
- 
This package contains the implementation of the backing data storage for the replicated map implementation 
- com.hazelcast.replicatedmap.merge - package com.hazelcast.replicatedmap.merge
- 
- com.hazelcast.ringbuffer - package com.hazelcast.ringbuffer
- 
- com.hazelcast.ringbuffer.impl - package com.hazelcast.ringbuffer.impl
- 
- com.hazelcast.ringbuffer.impl.client - package com.hazelcast.ringbuffer.impl.client
-  
- com.hazelcast.ringbuffer.impl.operations - package com.hazelcast.ringbuffer.impl.operations
-  
- com.hazelcast.security - package com.hazelcast.security
- 
Provides interfaces/classes for Hazelcast security implementation. 
- com.hazelcast.security.permission - package com.hazelcast.security.permission
- 
Contains all the security permissions 
- com.hazelcast.spi - package com.hazelcast.spi
- 
Provides interfaces/classes for the Hazelcast SPI for building distributed data structures and services. 
- com.hazelcast.spi.annotation - package com.hazelcast.spi.annotation
- 
Contains annotations for Hazelcast SPI. 
- com.hazelcast.spi.discovery - package com.hazelcast.spi.discovery
- 
This package contains the public SPI for vendors and users to implement their
 custom node / IP discovery strategy. 
- com.hazelcast.spi.discovery.impl - package com.hazelcast.spi.discovery.impl
-  
- com.hazelcast.spi.discovery.integration - package com.hazelcast.spi.discovery.integration
- 
This package contains the public part of the integrators SPI and is meant for
 people that integrate Hazelcast into their own systems or frameworks and cannot
 use the default discovery service implementation (for example using a different
  DiscoveryStrategy lookup strategy like OSGi). 
- com.hazelcast.spi.exception - package com.hazelcast.spi.exception
- 
Contains exceptions for Hazelcast SPI. 
- com.hazelcast.spi.impl - package com.hazelcast.spi.impl
- 
Contains implementations for Hazelcast SPI. 
- com.hazelcast.spi.impl.eventservice - package com.hazelcast.spi.impl.eventservice
- 
- com.hazelcast.spi.impl.eventservice.impl - package com.hazelcast.spi.impl.eventservice.impl
- 
- com.hazelcast.spi.impl.eventservice.impl.operations - package com.hazelcast.spi.impl.eventservice.impl.operations
- 
- com.hazelcast.spi.impl.executionservice - package com.hazelcast.spi.impl.executionservice
- 
- com.hazelcast.spi.impl.executionservice.impl - package com.hazelcast.spi.impl.executionservice.impl
- 
- com.hazelcast.spi.impl.operationexecutor - package com.hazelcast.spi.impl.operationexecutor
- 
- com.hazelcast.spi.impl.operationexecutor.classic - package com.hazelcast.spi.impl.operationexecutor.classic
- 
- com.hazelcast.spi.impl.operationexecutor.slowoperationdetector - package com.hazelcast.spi.impl.operationexecutor.slowoperationdetector
- 
- com.hazelcast.spi.impl.operationservice - package com.hazelcast.spi.impl.operationservice
- 
- com.hazelcast.spi.impl.operationservice.impl - package com.hazelcast.spi.impl.operationservice.impl
- 
- com.hazelcast.spi.impl.operationservice.impl.operations - package com.hazelcast.spi.impl.operationservice.impl.operations
- 
- com.hazelcast.spi.impl.operationservice.impl.responses - package com.hazelcast.spi.impl.operationservice.impl.responses
- 
Contains the different responses that can be send as a consequence of an Operation invocation. 
- com.hazelcast.spi.impl.operationutil - package com.hazelcast.spi.impl.operationutil
- 
- com.hazelcast.spi.impl.packetdispatcher - package com.hazelcast.spi.impl.packetdispatcher
- 
Contains the API for the dispatching packets to the appropriate internal services. 
- com.hazelcast.spi.impl.packetdispatcher.impl - package com.hazelcast.spi.impl.packetdispatcher.impl
- 
- com.hazelcast.spi.impl.proxyservice - package com.hazelcast.spi.impl.proxyservice
- 
- com.hazelcast.spi.impl.proxyservice.impl - package com.hazelcast.spi.impl.proxyservice.impl
- 
- com.hazelcast.spi.impl.proxyservice.impl.operations - package com.hazelcast.spi.impl.proxyservice.impl.operations
- 
- com.hazelcast.spi.impl.servicemanager - package com.hazelcast.spi.impl.servicemanager
- 
- com.hazelcast.spi.impl.servicemanager.impl - package com.hazelcast.spi.impl.servicemanager.impl
- 
- com.hazelcast.spi.impl.waitnotifyservice - package com.hazelcast.spi.impl.waitnotifyservice
- 
- com.hazelcast.spi.impl.waitnotifyservice.impl - package com.hazelcast.spi.impl.waitnotifyservice.impl
- 
- com.hazelcast.spring - package com.hazelcast.spring
- 
Provides Spring interfaces/classes for Hazelcast. 
- com.hazelcast.spring.cache - package com.hazelcast.spring.cache
- 
Contains Hazelcast cache classes related to Spring. 
- com.hazelcast.spring.context - package com.hazelcast.spring.context
- 
Contains context classes for Spring. 
- com.hazelcast.spring.hibernate - package com.hazelcast.spring.hibernate
- 
Contains class related to Hibernate. 
- com.hazelcast.topic - package com.hazelcast.topic
- 
Contains the API for the  ITopic. 
- com.hazelcast.topic.impl - package com.hazelcast.topic.impl
- 
This package contains ITopic functionality for Hazelcast.
 With the ITopic it is possible to create publish subscribe solutions similar to JMS Topics.
 
- com.hazelcast.topic.impl.client - package com.hazelcast.topic.impl.client
- 
This package contains client requests for the ITopic.
 
 
- com.hazelcast.topic.impl.reliable - package com.hazelcast.topic.impl.reliable
-  
- com.hazelcast.transaction - package com.hazelcast.transaction
- 
Provides interfaces/classes for Hazelcast transaction support. 
- com.hazelcast.transaction.client - package com.hazelcast.transaction.client
- 
This package contains client transaction code 
- com.hazelcast.transaction.impl - package com.hazelcast.transaction.impl
- 
Provides implementation for Hazelcast transaction support. 
- com.hazelcast.transaction.impl.operations - package com.hazelcast.transaction.impl.operations
-  
- com.hazelcast.transaction.impl.xa - package com.hazelcast.transaction.impl.xa
- 
Provides implementation for Hazelcast XA transaction support. 
- com.hazelcast.transaction.impl.xa.operations - package com.hazelcast.transaction.impl.xa.operations
-  
- com.hazelcast.util - package 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.util.collection - package com.hazelcast.util.collection
- 
The Agrona project backport: collections. 
- com.hazelcast.util.concurrent - package com.hazelcast.util.concurrent
- 
Abstractions that deal with common needs in concurrent programming. 
- com.hazelcast.util.counters - package com.hazelcast.util.counters
- 
Provides various counter implementations. 
- com.hazelcast.util.executor - package com.hazelcast.util.executor
- 
This package contains classes related to Util.Executor 
 
 
- com.hazelcast.util.function - package com.hazelcast.util.function
- 
Backport of Java 8 functional interfaces which Agrona depends on. 
- com.hazelcast.util.scheduler - package com.hazelcast.util.scheduler
- 
This package contains scheduler classes for Util 
- com.hazelcast.wan - package com.hazelcast.wan
- 
This package contains the WAN replication API 
- com.hazelcast.wan.impl - package com.hazelcast.wan.impl
- 
This package contains the opensource implementation of WAN replication 
- com.hazelcast.web - package com.hazelcast.web
- 
Provides Hazelcast-based session replication. 
- com.hazelcast.web.entryprocessor - package com.hazelcast.web.entryprocessor
- 
Provides Entry Processors used in hazelcast-wm 
- com.hazelcast.web.listener - package com.hazelcast.web.listener
- 
Provides LifecycleListeners for client and server 
- com.hazelcast.web.spring - package com.hazelcast.web.spring
- 
Provides Spring aware Hazelcast based session replication. 
- combine(ValueIn) - Method in class com.hazelcast.mapreduce.Combiner
- 
This method is called to supply values to be combined into an intermediate result chunk. 
 The combine method might be called multiple times so the combined chunk needs to be held
 internally in a member state of the Combiner. 
 After this method is called you need to  Combiner.reset() the internal state to prepare for combining of
 the next chunk. 
- Combiner<ValueIn,ValueOut> - Class in com.hazelcast.mapreduce
- 
 The abstract Combiner class is used to build combiners for the  Job. 
 Those Combiners are distributed inside of the cluster and are running alongside
 the  Mapper implementations in the same node.
  Combiners are called in a threadsafe way so internal locking is not required.
- Combiner() - Constructor for class com.hazelcast.mapreduce.Combiner
-  
- combiner(CombinerFactory<? super Key, ? super Value, ? extends ValueOut>) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.MappingJobImpl
-  
- combiner(CombinerFactory<? super KeyIn, ? super ValueIn, ? extends ValueOut>) - Method in interface com.hazelcast.mapreduce.MappingJob
- 
- COMBINER_RESULT_LIST - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-  
- CombinerFactory<KeyIn,ValueIn,ValueOut> - Interface in com.hazelcast.mapreduce
- 
 A CombinerFactory implementation is used to build  Combiner instances per key. 
 An implementation needs to be serializable by Hazelcast since it is distributed together with
 the  Mapper implementation to run alongside. 
- combinerFactory - Variable in class com.hazelcast.mapreduce.impl.AbstractJob
-  
- combinerFactory - Variable in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-  
- CombinerResultList<E> - Class in com.hazelcast.mapreduce.impl
- 
This  ArrayList subclass exists to prevent
  DefaultContext.CollectingCombinerFactory
 created collections to be mixed up with user provided List results from
  Combiners. 
- CombinerResultList() - Constructor for class com.hazelcast.mapreduce.impl.CombinerResultList
-  
- CombinerResultList(Collection<? extends E>) - Constructor for class com.hazelcast.mapreduce.impl.CombinerResultList
-  
- combineToInt(short, short) - Static method in class com.hazelcast.nio.Bits
- 
Combines two short integer values into an integer. 
- combineToLong(int, int) - Static method in class com.hazelcast.nio.Bits
- 
Combines two integer values into a long integer. 
- CommandParser - Interface in com.hazelcast.internal.ascii
-  
- CommaSeparatedKeyValueProbeRenderer - Class in com.hazelcast.internal.metrics.renderers
- 
- CommaSeparatedKeyValueProbeRenderer() - Constructor for class com.hazelcast.internal.metrics.renderers.CommaSeparatedKeyValueProbeRenderer
-  
- commit(Xid, boolean) - Method in class com.hazelcast.client.proxy.txn.xa.XAResourceProxy
-  
- commit(Xid, boolean) - Method in class com.hazelcast.client.txn.proxy.xa.XAResourceProxy
-  
- commit() - Method in class com.hazelcast.jca.HazelcastTransactionImpl
-  
- COMMIT - Static variable in class com.hazelcast.transaction.client.ClientTxnPortableHook
-  
- commit() - Method in interface com.hazelcast.transaction.impl.Transaction
-  
- commit() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-  
- commit(NodeEngine) - Method in class com.hazelcast.transaction.impl.TransactionLog
-  
- commit(Xid, boolean) - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
-  
- commit() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
-  
- COMMIT_XA - Static variable in class com.hazelcast.transaction.client.ClientTxnPortableHook
-  
- commitAdd(long, Data) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- commitAddBackup(long, Data) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- commitAsync(NodeEngine, ExecutionCallback) - Method in class com.hazelcast.transaction.impl.TransactionLog
-  
- commitAsync(ExecutionCallback) - Method in class com.hazelcast.transaction.impl.xa.XATransaction
-  
- commitClusterState(ClusterState, Address, String) - Method in class com.hazelcast.cluster.impl.ClusterStateManager
-  
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.collection.impl.collection.CollectionService
-  
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-  
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-  
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-  
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-  
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-  
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.map.impl.MapService
-  
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-  
- commitMigration(PartitionMigrationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
-  
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.transaction.impl.xa.XAService
-  
- commitRemove(long) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- commitRemoveBackup(long) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- commitTransaction() - Method in class com.hazelcast.client.proxy.txn.TransactionContextProxy
-  
- commitTransaction() - Method in class com.hazelcast.client.proxy.txn.xa.XATransactionContextProxy
-  
- commitTransaction() - Method in class com.hazelcast.client.txn.proxy.xa.XATransactionContextProxy
-  
- commitTransaction() - Method in class com.hazelcast.client.txn.TransactionContextProxy
-  
- commitTransaction() - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
-  
- commitTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
- 
Commits a transaction. 
- CommitTransactionRequest - Class in com.hazelcast.transaction.client
-  
- CommitTransactionRequest() - Constructor for class com.hazelcast.transaction.client.CommitTransactionRequest
-  
- CommitXATransactionRequest - Class in com.hazelcast.transaction.client
-  
- CommitXATransactionRequest() - Constructor for class com.hazelcast.transaction.client.CommitXATransactionRequest
-  
- CommitXATransactionRequest(String, boolean) - Constructor for class com.hazelcast.transaction.client.CommitXATransactionRequest
-  
- compact() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
-  
- compact() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
- 
Compact the  Map backing arrays by rehashing with a capacity just larger than current size
 and giving consideration to the load factor. 
- compact() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
- 
Compact the  Map backing arrays by rehashing with a capacity just larger than current size
 and giving consideration to the load factor. 
- COMPARABLE_MAX_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- COMPARABLE_MAX_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- COMPARABLE_MIN_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- COMPARABLE_MIN_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- comparableMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
- 
Returns an aggregation to find the maximum value of all supplied
  Comparable implementing values. 
 This aggregation is similar to: 
- ComparableMaxAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
- 
The predefined maximum aggregation for values of type  Comparable. 
- ComparableMaxAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.ComparableMaxAggregation
-  
- comparableMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
- 
Returns an aggregation to find the minimum value of all supplied
  Comparable implementing values. 
 This aggregation is similar to: 
- ComparableMinAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
- 
The predefined minimum aggregation for values of type  Comparable. 
- ComparableMinAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.ComparableMinAggregation
-  
- compare(Object, Object) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- compare(Comparator<Map.Entry>, IterationType, Map.Entry, Map.Entry) - Static method in class com.hazelcast.util.SortingUtil
-  
- COMPARE_AND_REMOVE - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-  
- COMPARE_AND_REMOVE - Static variable in class com.hazelcast.collection.impl.queue.QueuePortableHook
-  
- COMPARE_AND_REMOVE - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- COMPARE_AND_REMOVE_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-  
- COMPARE_AND_REMOVE_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- COMPARE_AND_SET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-  
- COMPARE_AND_SET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-  
- compareAnchor(PagingPredicate, QueryableEntry, Map.Entry<Integer, Map.Entry>) - Static method in class com.hazelcast.util.SortingUtil
-  
- compareAndRemove(boolean, Set<Data>) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- compareAndRemove(Collection<Data>, boolean) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
- 
This method triggers store load 
- compareAndRemoveBackup(Set<Long>) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- CompareAndRemoveBackupOperation - Class in com.hazelcast.collection.impl.queue.operations
- 
This class triggers backup method for items' id. 
- CompareAndRemoveBackupOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveBackupOperation
-  
- CompareAndRemoveBackupOperation(String, Set<Long>) - Constructor for class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveBackupOperation
-  
- CompareAndRemoveOperation - Class in com.hazelcast.collection.impl.queue.operations
- 
This class triggers iterator and if find same item in the Queue, remove this item. 
- CompareAndRemoveOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
-  
- CompareAndRemoveOperation(String, Collection<Data>, boolean) - Constructor for class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
-  
- CompareAndRemoveRequest - Class in com.hazelcast.collection.impl.queue.client
- 
- CompareAndRemoveRequest() - Constructor for class com.hazelcast.collection.impl.queue.client.CompareAndRemoveRequest
-  
- CompareAndRemoveRequest(String, Collection<Data>, boolean) - Constructor for class com.hazelcast.collection.impl.queue.client.CompareAndRemoveRequest
-  
- compareAndSet(long, long) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-  
- compareAndSet(E, E) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-  
- compareAndSet(long, long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
-  
- compareAndSet(long, long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- compareAndSet(Data, Data) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceContainer
-  
- compareAndSet(E, E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- compareAndSet(long, long) - Method in interface com.hazelcast.core.IAtomicLong
- 
Atomically sets the value to the given updated value
 only if the current value ==the expected value.
 
- compareAndSet(E, E) - Method in interface com.hazelcast.core.IAtomicReference
- 
Atomically sets the value to the given updated value
 only if the current value ==the expected value.
 
- compareAndSet(long, long) - Method in class com.hazelcast.jmx.AtomicLongMBean
-  
- CompareAndSetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-  
- CompareAndSetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
-  
- CompareAndSetOperation(String, long, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
-  
- CompareAndSetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-  
- CompareAndSetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
-  
- CompareAndSetOperation(String, Data, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
-  
- CompareAndSetRequest - Class in com.hazelcast.concurrent.atomiclong.client
-  
- CompareAndSetRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.CompareAndSetRequest
-  
- CompareAndSetRequest(String, long, long) - Constructor for class com.hazelcast.concurrent.atomiclong.client.CompareAndSetRequest
-  
- CompareAndSetRequest - Class in com.hazelcast.concurrent.atomicreference.client
-  
- CompareAndSetRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.CompareAndSetRequest
-  
- CompareAndSetRequest(String, Data, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.CompareAndSetRequest
-  
- compareIntegers(int, int) - Static method in class com.hazelcast.util.QuickMath
- 
Compares two integers 
- compareLongs(long, long) - Static method in class com.hazelcast.util.QuickMath
- 
Compares two longs 
- compareTo(CollectionItem) - Method in class com.hazelcast.collection.impl.collection.CollectionItem
-  
- compareTo(QueueItem) - Method in class com.hazelcast.collection.impl.queue.QueueItem
-  
- compareTo(MonitoredThread) - Method in class com.hazelcast.internal.management.MonitoredThread
-  
- compareTo(Object) - Method in class com.hazelcast.partition.PartitionServiceProxy.PartitionProxy
-  
- compareTo(Object) - Method in class com.hazelcast.query.impl.IndexImpl.NullObject
-  
- ComparisonType - Enum in com.hazelcast.query.impl
- 
Type of Comparison 
- CompletableFutureTask<V> - Class in com.hazelcast.util.executor
-  
- CompletableFutureTask(Callable<V>, ExecutorService) - Constructor for class com.hazelcast.util.executor.CompletableFutureTask
-  
- CompletableFutureTask(Runnable, V, ExecutorService) - Constructor for class com.hazelcast.util.executor.CompletableFutureTask
-  
- complete() - Method in class com.hazelcast.client.spi.impl.CallIdSequence.CallIdSequenceFailFast
-  
- complete() - Method in class com.hazelcast.client.spi.impl.CallIdSequence
-  
- complete(Invocation) - Method in class com.hazelcast.spi.impl.operationservice.impl.CallIdSequence.CallIdSequenceWithBackpressure
-  
- complete(Invocation) - Method in class com.hazelcast.spi.impl.operationservice.impl.CallIdSequence.CallIdSequenceWithoutBackpressure
-  
- complete(Invocation) - Method in class com.hazelcast.spi.impl.operationservice.impl.CallIdSequence
-  
- CompletedFuture<V> - Class in com.hazelcast.util.executor
-  
- CompletedFuture(SerializationService, Object, ExecutorService) - Constructor for class com.hazelcast.util.executor.CompletedFuture
-  
- completedTaskCount - Variable in class com.hazelcast.internal.management.dto.ManagedExecutorDTO
-  
- CompletionAwareCacheRequest - Interface in com.hazelcast.cache.impl.client
- 
Contract point for cache requests these handle a completion id registration. 
- completionId - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-  
- completionId - Variable in class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
-  
- CompositeMaxSizeChecker - Class in com.hazelcast.cache.impl.maxsize.impl
- 
- CompositeMaxSizeChecker(MaxSizeChecker...) - Constructor for class com.hazelcast.cache.impl.maxsize.impl.CompositeMaxSizeChecker
-  
- CompositeMaxSizeChecker.CompositionOperator - Enum in com.hazelcast.cache.impl.maxsize.impl
- 
- compress(byte[]) - Static method in class com.hazelcast.nio.IOUtil
-  
- computeIfAbsent(int, IntFunction<? extends V>) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
- 
Get a value for a given key, or if it does ot exist then default the value via a  IntFunction
 and put it in the map. 
- computeIfAbsent(long, LongFunction<? extends V>) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
- 
Get a value for a given key, or if it does ot exist then default the value via a  LongFunction
 and put it in the map. 
- ComputeServiceBuilder - Class in com.hazelcast.jclouds
- 
ComputeServiceBuilder is the responsible class for building jclouds compute service provider. 
- concatenate(byte[], byte[]) - Static method in class com.hazelcast.internal.ascii.memcache.MemcacheCommandProcessor
-  
- ConcurrencyUtil - Class in com.hazelcast.util
- 
Utility methods to getOrPutSynchronized and getOrPutIfAbsent in a thread safe way
 from ConcurrentMap with a ConstructorFunction. 
- CONCURRENT_MODIFICATION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- ConcurrentReferenceHashMap<K,V> - Class in com.hazelcast.util
- 
An advanced hash table supporting configurable garbage collection semantics
 of keys and values, optional referential-equality, full concurrency of
 retrievals, and adjustable expected concurrency for updates. 
- ConcurrentReferenceHashMap(int, float, int, ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType, EnumSet<ConcurrentReferenceHashMap.Option>) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
- 
Creates a new, empty map with the specified initial
 capacity, reference types, load factor, and concurrency level. 
- ConcurrentReferenceHashMap(int, float, int) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
- 
Creates a new, empty map with the specified initial
 capacity, load factor, and concurrency level. 
- ConcurrentReferenceHashMap(int, float) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
- 
Creates a new, empty map with the specified initial capacity
 and load factor and with the default reference types (weak keys,
 strong values), and concurrencyLevel (16). 
- ConcurrentReferenceHashMap(int, ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
- 
Creates a new, empty map with the specified initial capacity,
 reference types, and with a default load factor (0.75) and concurrencyLevel (16). 
- ConcurrentReferenceHashMap(ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
- 
Creates a new, empty reference map with the specified key
 and value reference types. 
- ConcurrentReferenceHashMap(ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType, EnumSet<ConcurrentReferenceHashMap.Option>) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
- 
Creates a new, empty reference map with the specified reference types
 and behavioral options. 
- ConcurrentReferenceHashMap(int) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
- 
Creates a new, empty map with the specified initial capacity,
 and with default reference types (weak keys, strong values),
 load factor (0.75) and concurrencyLevel (16). 
- ConcurrentReferenceHashMap() - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
- 
Creates a new, empty map with a default initial capacity (16),
 reference types (weak keys, strong values), default
 load factor (0.75) and concurrencyLevel (16). 
- ConcurrentReferenceHashMap(Map<? extends K, ? extends V>) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
- 
Creates a new map with the same mappings as the given map. 
- ConcurrentReferenceHashMap.Option - Enum in com.hazelcast.util
- 
Behavior-changing configuration options for the map 
- ConcurrentReferenceHashMap.ReferenceType - Enum in com.hazelcast.util
- 
An option specifying which Java reference type should be used to refer
 to a key and/or value. 
- ConcurrentReferenceHashMap.SimpleEntry<K,V> - Class in com.hazelcast.util
-  
- ConcurrentReferenceHashMap.SimpleEntry(K, V) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap.SimpleEntry
-  
- ConcurrentReferenceHashMap.SimpleEntry(Map.Entry<? extends K, ? extends V>) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap.SimpleEntry
-  
- ConcurrentReferenceHashMap.WriteThroughEntry - Class in com.hazelcast.util
- 
Custom Entry class used by EntryIterator.next(), that relays setValue
 changes to the underlying map. 
- ConcurrentReferenceHashMap.WriteThroughEntry(K, V) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap.WriteThroughEntry
-  
- CONDITION_AWAIT - Static variable in class com.hazelcast.concurrent.lock.client.LockPortableHook
-  
- CONDITION_BEFORE_AWAIT - Static variable in class com.hazelcast.concurrent.lock.client.LockPortableHook
-  
- CONDITION_SIGNAL - Static variable in class com.hazelcast.concurrent.lock.client.LockPortableHook
-  
- ConditionAwaitMessageTask - Class in com.hazelcast.client.impl.protocol.task.condition
-  
- ConditionAwaitMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.condition.ConditionAwaitMessageTask
-  
- ConditionBeforeAwaitMessageTask - Class in com.hazelcast.client.impl.protocol.task.condition
-  
- ConditionBeforeAwaitMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.condition.ConditionBeforeAwaitMessageTask
-  
- ConditionKey - Class in com.hazelcast.concurrent.lock
-  
- ConditionKey(String, Data, String) - Constructor for class com.hazelcast.concurrent.lock.ConditionKey
-  
- ConditionSignalAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.condition
-  
- ConditionSignalAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalAllMessageTask
-  
- ConditionSignalMessageTask - Class in com.hazelcast.client.impl.protocol.task.condition
-  
- ConditionSignalMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalMessageTask
-  
- config - Variable in class com.hazelcast.cluster.impl.AbstractJoiner
-  
- config - Variable in class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxySupport
-  
- Config - Class in com.hazelcast.config
- 
- Config() - Constructor for class com.hazelcast.config.Config
-  
- Config(String) - Constructor for class com.hazelcast.config.Config
-  
- config - Variable in class com.hazelcast.hibernate.local.LocalRegionCache
-  
- config - Variable in class com.hazelcast.instance.Node
-  
- config - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- config - Variable in class com.hazelcast.multimap.impl.MultiMapProxySupport
-  
- config - Variable in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-  
- CONFIG_CHECK - Static variable in class com.hazelcast.cluster.impl.ClusterDataSerializerHook
-  
- CONFIG_FILE_PATH - Static variable in class com.hazelcast.hibernate.CacheEnvironment
- 
Property to configure the path of the hazelcast.xml or hazelcast-client.xml configuration files 
- CONFIG_FILE_PATH_LEGACY - Static variable in class com.hazelcast.hibernate.CacheEnvironment
- 
Deprecated. 
- CONFIG_MISMATCH - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- ConfigBuilder - Interface in com.hazelcast.config
- 
Interface for all config builders. 
- configBuilder - Variable in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
-  
- ConfigCheck - Class in com.hazelcast.cluster.impl
- 
Contains enough information about Hazelcast Config, to do a validation check so that clusters with different configurations
 don't join. 
- ConfigCheck() - Constructor for class com.hazelcast.cluster.impl.ConfigCheck
-  
- ConfigCheck(Config, String) - Constructor for class com.hazelcast.cluster.impl.ConfigCheck
-  
- configCheck - Variable in class com.hazelcast.cluster.impl.JoinMessage
-  
- ConfigLoader - Class in com.hazelcast.config
- 
Provides loading service for a configuration. 
- ConfigMemberGroupFactory - Class in com.hazelcast.partition.membergroup
-  
- ConfigMemberGroupFactory(Collection<MemberGroupConfig>) - Constructor for class com.hazelcast.partition.membergroup.ConfigMemberGroupFactory
-  
- ConfigMismatchException - Exception in com.hazelcast.cluster.impl
- 
Exception thrown when 2 nodes want to join, but there configuration doesn't match 
- ConfigMismatchException(String) - Constructor for exception com.hazelcast.cluster.impl.ConfigMismatchException
-  
- ConfigMismatchOperation - Class in com.hazelcast.cluster.impl.operations
- 
When a node wants to join the cluster, its sends its ConfigCheck to the cluster where it is validated. 
- ConfigMismatchOperation() - Constructor for class com.hazelcast.cluster.impl.operations.ConfigMismatchOperation
-  
- ConfigMismatchOperation(String) - Constructor for class com.hazelcast.cluster.impl.operations.ConfigMismatchOperation
-  
- ConfigPatternMatcher - Interface in com.hazelcast.config
- 
The ConfigPatternMatcher provides a strategy to match an item name to a configuration pattern. 
- configs - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-  
- configs - Variable in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
-  
- ConfigurableService<T> - Interface in com.hazelcast.spi
- 
A capability for SPI services. 
- CONFIGURATION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- ConfigurationException - Exception in com.hazelcast.config
- 
A  HazelcastException that is thrown when something is wrong with the server or client configuration. 
- ConfigurationException(String, String, String) - Constructor for exception com.hazelcast.config.ConfigurationException
-  
- ConfigurationException(String) - Constructor for exception com.hazelcast.config.ConfigurationException
-  
- configure(Properties) - Method in interface com.hazelcast.hibernate.instance.IHazelcastInstanceLoader
- 
Applies a set of properties to the factory 
- configure(GroupConfig, Properties) - Method in interface com.hazelcast.security.ICredentialsFactory
- 
- configure(Config, Properties) - Method in interface com.hazelcast.security.IPermissionPolicy
- 
- configure(T) - Method in interface com.hazelcast.spi.ConfigurableService
-  
- configureBlocking(boolean) - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-  
- configureBlocking(boolean) - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-  
- ConfigXmlGenerator - Class in com.hazelcast.config
- 
The ConfigXmlGenerator is responsible for transforming a  Config to a Hazelcast XML string. 
- ConfigXmlGenerator() - Constructor for class com.hazelcast.config.ConfigXmlGenerator
- 
Creates a ConfigXmlGenerator that will format the code. 
- ConfigXmlGenerator(boolean) - Constructor for class com.hazelcast.config.ConfigXmlGenerator
- 
Creates a ConfigXmlGenerator. 
- connect() - Method in class com.hazelcast.client.spi.impl.ClientTransactionManagerServiceImpl
-  
- connect(SocketAddress) - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-  
- connect(SocketAddress) - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-  
- connection - Variable in class com.hazelcast.client.connection.nio.AbstractClientSelectionHandler
-  
- connection - Variable in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-  
- Connection - Interface in com.hazelcast.nio
- 
Represents a 'connection' between two machines. 
- connection - Variable in class com.hazelcast.nio.tcp.MemberReadHandler
-  
- connection - Variable in class com.hazelcast.nio.tcp.nonblocking.AbstractHandler
-  
- connection - Variable in class com.hazelcast.nio.tcp.spinning.AbstractHandler
-  
- connectionAdded(Connection) - Method in class com.hazelcast.client.spi.impl.ClusterListenerSupport
-  
- connectionAdded(Connection) - Method in class com.hazelcast.client.spi.impl.listener.ClientNonSmartListenerService
-  
- connectionAdded(Connection) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- connectionAdded(Connection) - Method in interface com.hazelcast.nio.ConnectionListener
-  
- connectionAdded(TcpIpConnection) - Method in class com.hazelcast.nio.tcp.nonblocking.iobalancer.IOBalancer
-  
- connectionCount - Variable in class com.hazelcast.internal.management.dto.ConnectionManagerDTO
-  
- ConnectionFactoryImpl - Class in com.hazelcast.jca
- 
Small facade to bring together container's pooling mechanism and other
 vendor-specific calls with the real implementation classes of this
 resource adapter 
- ConnectionFactoryImpl() - Constructor for class com.hazelcast.jca.ConnectionFactoryImpl
-  
- ConnectionFactoryImpl(ManagedConnectionFactoryImpl, ConnectionManager) - Constructor for class com.hazelcast.jca.ConnectionFactoryImpl
-  
- ConnectionHeartbeatListener - Interface in com.hazelcast.client.spi.impl
- 
- connectionId - Variable in class com.hazelcast.client.connection.nio.ClientConnection
-  
- connectionIdGen - Variable in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-  
- ConnectionListener - Interface in com.hazelcast.nio
- 
A listener for the  ConnectionManager to listen to connections
 being added or removed. 
- connectionManager - Variable in class com.hazelcast.client.connection.nio.AbstractClientSelectionHandler
-  
- connectionManager - Variable in class com.hazelcast.instance.Node
-  
- ConnectionManager - Interface in com.hazelcast.nio
- 
- connectionManager - Variable in class com.hazelcast.nio.tcp.nonblocking.AbstractHandler
-  
- connectionManager - Variable in class com.hazelcast.nio.tcp.spinning.AbstractHandler
-  
- ConnectionManagerDTO - Class in com.hazelcast.internal.management.dto
- 
- ConnectionManagerDTO() - Constructor for class com.hazelcast.internal.management.dto.ConnectionManagerDTO
-  
- ConnectionManagerDTO(ConnectionManager) - Constructor for class com.hazelcast.internal.management.dto.ConnectionManagerDTO
-  
- ConnectionManagerMBean - Class in com.hazelcast.jmx
- 
- ConnectionManagerMBean(HazelcastInstance, ConnectionManager, ManagementService) - Constructor for class com.hazelcast.jmx.ConnectionManagerMBean
-  
- connectionRemoved(Connection) - Method in class com.hazelcast.client.spi.impl.ClusterListenerSupport
-  
- connectionRemoved(Connection) - Method in class com.hazelcast.client.spi.impl.listener.ClientNonSmartListenerService
-  
- connectionRemoved(Connection) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- connectionRemoved(Connection) - Method in interface com.hazelcast.nio.ConnectionListener
-  
- connectionRemoved(TcpIpConnection) - Method in class com.hazelcast.nio.tcp.nonblocking.iobalancer.IOBalancer
-  
- ConnectionType - Enum in com.hazelcast.nio
- 
An enumeration of all possible Connection types. 
- connectToCluster() - Method in class com.hazelcast.client.spi.impl.ClusterListenerSupport
-  
- ConsoleApp - Class in com.hazelcast.console
- 
Special thanks to Alexandre Vasseur for providing this very nice test
 application. 
- ConsoleApp(HazelcastInstance) - Constructor for class com.hazelcast.console.ConsoleApp
-  
- ConsoleCommandHandler - Class in com.hazelcast.internal.management
- 
Handler class for console commands that sent from Console application which located in Management Center. 
- ConsoleCommandHandler(HazelcastInstance) - Constructor for class com.hazelcast.internal.management.ConsoleCommandHandler
-  
- ConsoleCommandRequest - Class in com.hazelcast.internal.management.request
- 
Request for sending console commands. 
- ConsoleCommandRequest() - Constructor for class com.hazelcast.internal.management.request.ConsoleCommandRequest
-  
- ConsoleCommandRequest(String) - Constructor for class com.hazelcast.internal.management.request.ConsoleCommandRequest
-  
- ConsoleRequest - Interface in com.hazelcast.internal.management.request
- 
Represents request sent from Management Center. 
- ConsoleRequestConstants - Class in com.hazelcast.internal.management.request
- 
Constants to identify serialized requests. 
- CONSTANT_SERIALIZERS_LENGTH - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_BOOLEAN - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_BOOLEAN_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_BYTE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_BYTE_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_CHAR - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_CHAR_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_DATA_SERIALIZABLE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_DOUBLE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_DOUBLE_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_FLOAT - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_FLOAT_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_INTEGER - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_INTEGER_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_LONG - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_LONG_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_NULL - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_PORTABLE - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_SHORT - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_SHORT_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_STRING - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- CONSTANT_TYPE_STRING_ARRAY - Static variable in class com.hazelcast.internal.serialization.impl.SerializationConstants
-  
- Constants - Class in com.hazelcast.aws.impl
-  
- Constants() - Constructor for class com.hazelcast.aws.impl.Constants
-  
- ConstantSerializers - Class in com.hazelcast.internal.serialization.impl
-  
- ConstantSerializers.BooleanArraySerializer - Class in com.hazelcast.internal.serialization.impl
-  
- ConstantSerializers.BooleanArraySerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.BooleanArraySerializer
-  
- ConstantSerializers.BooleanSerializer - Class in com.hazelcast.internal.serialization.impl
-  
- ConstantSerializers.BooleanSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.BooleanSerializer
-  
- ConstantSerializers.ByteSerializer - Class in com.hazelcast.internal.serialization.impl
-  
- ConstantSerializers.ByteSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.ByteSerializer
-  
- ConstantSerializers.CharArraySerializer - Class in com.hazelcast.internal.serialization.impl
-  
- ConstantSerializers.CharArraySerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.CharArraySerializer
-  
- ConstantSerializers.CharSerializer - Class in com.hazelcast.internal.serialization.impl
-  
- ConstantSerializers.CharSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.CharSerializer
-  
- ConstantSerializers.DoubleArraySerializer - Class in com.hazelcast.internal.serialization.impl
-  
- ConstantSerializers.DoubleArraySerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.DoubleArraySerializer
-  
- ConstantSerializers.DoubleSerializer - Class in com.hazelcast.internal.serialization.impl
-  
- ConstantSerializers.DoubleSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.DoubleSerializer
-  
- ConstantSerializers.FloatArraySerializer - Class in com.hazelcast.internal.serialization.impl
-  
- ConstantSerializers.FloatArraySerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.FloatArraySerializer
-  
- ConstantSerializers.FloatSerializer - Class in com.hazelcast.internal.serialization.impl
-  
- ConstantSerializers.FloatSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.FloatSerializer
-  
- ConstantSerializers.IntegerArraySerializer - Class in com.hazelcast.internal.serialization.impl
-  
- ConstantSerializers.IntegerArraySerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.IntegerArraySerializer
-  
- ConstantSerializers.IntegerSerializer - Class in com.hazelcast.internal.serialization.impl
-  
- ConstantSerializers.IntegerSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.IntegerSerializer
-  
- ConstantSerializers.LongArraySerializer - Class in com.hazelcast.internal.serialization.impl
-  
- ConstantSerializers.LongArraySerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.LongArraySerializer
-  
- ConstantSerializers.LongSerializer - Class in com.hazelcast.internal.serialization.impl
-  
- ConstantSerializers.LongSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.LongSerializer
-  
- ConstantSerializers.NullSerializer - Class in com.hazelcast.internal.serialization.impl
-  
- ConstantSerializers.NullSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.NullSerializer
-  
- ConstantSerializers.ShortArraySerializer - Class in com.hazelcast.internal.serialization.impl
-  
- ConstantSerializers.ShortArraySerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.ShortArraySerializer
-  
- ConstantSerializers.ShortSerializer - Class in com.hazelcast.internal.serialization.impl
-  
- ConstantSerializers.ShortSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.ShortSerializer
-  
- ConstantSerializers.StringArraySerializer - Class in com.hazelcast.internal.serialization.impl
-  
- ConstantSerializers.StringArraySerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.StringArraySerializer
-  
- ConstantSerializers.StringSerializer - Class in com.hazelcast.internal.serialization.impl
-  
- ConstantSerializers.StringSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.StringSerializer
-  
- ConstantSerializers.TheByteArraySerializer - Class in com.hazelcast.internal.serialization.impl
-  
- ConstantSerializers.TheByteArraySerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ConstantSerializers.TheByteArraySerializer
-  
- constructorFunction - Variable in class com.hazelcast.map.impl.LocalMapStatsProvider
-  
- ConstructorFunction<K,V> - Interface in com.hazelcast.util
- 
See ConcurrencyUtil 
- Consumer<T> - Interface in com.hazelcast.util.function
- 
Represents an operation that accepts a single input argument and returns no
 result. 
- container - Variable in class com.hazelcast.collection.impl.queue.QueueItem
-  
- contains(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- contains(Data) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Determines if this store contains an entry for the specified key. 
- contains(Object) - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
-  
- contains(E) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-  
- contains(Object) - Method in class com.hazelcast.client.proxy.ClientListProxy
-  
- contains(Object) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-  
- contains(Object) - Method in class com.hazelcast.client.proxy.ClientSetProxy
-  
- contains(Object) - Method in class com.hazelcast.cluster.impl.MemberSelectingCollection
-  
- contains(Object) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-  
- contains(Set<Data>) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- contains(Collection<Data>) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
- 
This method does not trigger store load. 
- CONTAINS - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-  
- CONTAINS - Static variable in class com.hazelcast.collection.impl.queue.QueuePortableHook
-  
- contains(Object) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
-  
- contains(Data) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceContainer
-  
- CONTAINS - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-  
- contains(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- contains(E) - Method in interface com.hazelcast.core.IAtomicReference
- 
Checks if the reference contains the value. 
- contains(Object) - Method in class com.hazelcast.hibernate.distributed.IMapRegionCache
-  
- contains(Object) - Method in class com.hazelcast.hibernate.local.LocalRegionCache
-  
- contains(Object) - Method in interface com.hazelcast.hibernate.RegionCache
-  
- contains(E) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
- 
Checks whether an element exist in this queue. 
- CONTAINS - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- contains(Object) - Method in class com.hazelcast.query.impl.AndResultSet
-  
- contains(Object) - Method in class com.hazelcast.query.impl.DuplicateDetectingMultiResult
-  
- contains(Object) - Method in class com.hazelcast.query.impl.FastMultiResultSet
-  
- contains(Object) - Method in class com.hazelcast.query.impl.OrResultSet
-  
- contains(Object) - Method in class com.hazelcast.query.impl.SingleResultSet
-  
- contains(T[], T) - Static method in class com.hazelcast.util.collection.ArrayUtils
-  
- contains(Object) - Method in class com.hazelcast.util.collection.InflatableSet
-  
- contains(Object) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
-  
- contains(int) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
-  
- contains(Object) - Method in class com.hazelcast.util.collection.IntHashSet
- contains(int) - Method in class com.hazelcast.util.collection.IntHashSet
- contains(Object) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
-  
- contains(long) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
-  
- contains(Object) - Method in class com.hazelcast.util.collection.LongHashSet
- contains(long) - Method in class com.hazelcast.util.collection.LongHashSet
- contains(Object) - Method in class com.hazelcast.util.collection.MapDelegatingSet
- contains(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
- 
Legacy method testing if some key maps into the specified value
 in this table. 
- CONTAINS_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- CONTAINS_ENTRY - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- CONTAINS_ENTRY - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-  
- CONTAINS_KEY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- CONTAINS_KEY - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- CONTAINS_KEY - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- CONTAINS_KEY - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-  
- CONTAINS_VALUE - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- CONTAINS_VALUE - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-  
- containsAll(Collection<?>) - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
-  
- containsAll(Collection<?>) - Method in class com.hazelcast.client.proxy.ClientListProxy
-  
- containsAll(Collection<?>) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-  
- containsAll(Collection<?>) - Method in class com.hazelcast.client.proxy.ClientSetProxy
-  
- containsAll(Collection<?>) - Method in class com.hazelcast.cluster.impl.MemberSelectingCollection
-  
- containsAll(Collection<?>) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-  
- containsAll(Collection<?>) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
-  
- containsAll(Collection<?>) - Method in class com.hazelcast.util.collection.IntHashSet
- containsAll(IntHashSet) - Method in class com.hazelcast.util.collection.IntHashSet
- 
IntHashSet specialised variant of {this#containsAll(Collection)}. 
- containsAll(Collection<?>) - Method in class com.hazelcast.util.collection.LongHashSet
- containsAll(LongHashSet) - Method in class com.hazelcast.util.collection.LongHashSet
- 
LongHashSet specialised variant of {this#containsAll(Collection)}. 
- containsAtomicLong(String) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-  
- containsCollection(String) - Method in class com.hazelcast.multimap.impl.MultiMapPartitionContainer
-  
- containsEntry(K, V) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-  
- containsEntry(K, V) - Method in interface com.hazelcast.core.MultiMap
- 
Returns whether the multimap contains the given key-value pair. 
- containsEntry(boolean, Data, Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-  
- containsEntry(K, V) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-  
- ContainsEntryOperation - Class in com.hazelcast.multimap.impl.operations
-  
- ContainsEntryOperation() - Constructor for class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-  
- ContainsEntryOperation(String, Data, Data) - Constructor for class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-  
- ContainsEntryOperation(String, Data, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-  
- containsInternal(Data, Data) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-  
- containsKey(K) - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- containsKey(K) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- containsKey(Object) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- containsKey(K) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-  
- containsKey(Object) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-  
- containsKey(Object) - Method in class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-  
- containsKey(Object) - Method in class com.hazelcast.client.txn.proxy.ClientTxnMapProxy
-  
- containsKey(Object) - Method in interface com.hazelcast.core.BaseMap
- 
Returns trueif this map contains an entry for the specified
 key.
 
- containsKey(Object) - Method in interface com.hazelcast.core.IMap
- 
Returns trueif this map contains an entry for the specified
 key.
 
- containsKey(K) - Method in interface com.hazelcast.core.MultiMap
- 
Returns whether the multimap contains an entry with the key. 
- containsKey(Object) - Method in interface com.hazelcast.core.TransactionalMap
- 
- containsKey(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- containsKey(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- containsKey(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- containsKey(K) - Method in interface com.hazelcast.map.impl.recordstore.Storage
-  
- containsKey(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-  
- containsKey(Object) - Method in interface com.hazelcast.map.QueryCache
-  
- containsKey(Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-  
- containsKey(K) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-  
- containsKey(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-  
- containsKey(Object) - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
-  
- containsKey(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- containsKey(Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-  
- containsKey(Object) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
- containsKey(int) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
- 
- containsKey(long) - Method in class com.hazelcast.util.collection.Long2LongHashMap
- 
Long primitive specialised containsKey. 
- containsKey(Object) - Method in class com.hazelcast.util.collection.Long2LongHashMap
- containsKey(Object) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
- containsKey(long) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
- 
- containsKey(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
- 
Tests if the specified object is a key in this table. 
- containsKeyInternal(Data) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- containsKeyInternal(Data) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- containsKeyInternal(Data) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- containsKeyInternal(Data) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-  
- ContainsKeyOperation - Class in com.hazelcast.map.impl.operation
-  
- ContainsKeyOperation() - Constructor for class com.hazelcast.map.impl.operation.ContainsKeyOperation
-  
- ContainsKeyOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.ContainsKeyOperation
-  
- ContainsKeyOperation - Class in com.hazelcast.replicatedmap.impl.operation
-  
- ContainsKeyOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ContainsKeyOperation
-  
- ContainsKeyOperation(String, Data) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ContainsKeyOperation
-  
- containsLatch(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-  
- ContainsOperation - Class in com.hazelcast.collection.impl.queue.operations
- 
Checks whether contain or not item in the Queue. 
- ContainsOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.ContainsOperation
-  
- ContainsOperation(String, Collection<Data>) - Constructor for class com.hazelcast.collection.impl.queue.operations.ContainsOperation
-  
- ContainsOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-  
- ContainsOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
-  
- ContainsOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
-  
- containsQueue(String) - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- containsRecordId(long) - Method in class com.hazelcast.multimap.impl.MultiMapValue
-  
- ContainsRequest - Class in com.hazelcast.collection.impl.queue.client
- 
- ContainsRequest() - Constructor for class com.hazelcast.collection.impl.queue.client.ContainsRequest
-  
- ContainsRequest(String, Collection<Data>) - Constructor for class com.hazelcast.collection.impl.queue.client.ContainsRequest
-  
- ContainsRequest - Class in com.hazelcast.concurrent.atomicreference.client
-  
- ContainsRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.ContainsRequest
-  
- ContainsRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.ContainsRequest
-  
- ContainsRequest - Class in com.hazelcast.multimap.impl.client
- 
The contains requests checks if a value is stored in the multimap. 
- ContainsRequest() - Constructor for class com.hazelcast.multimap.impl.client.ContainsRequest
-  
- ContainsRequest(String, Data) - Constructor for class com.hazelcast.multimap.impl.client.ContainsRequest
-  
- containsSemaphore(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-  
- containsValue(Object) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- containsValue(Object) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-  
- containsValue(Object) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-  
- containsValue(Object) - Method in interface com.hazelcast.core.IMap
- containsValue(Object) - Method in interface com.hazelcast.core.MultiMap
- 
Returns whether the multimap contains an entry with the value. 
- containsValue(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- containsValue(Object) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- containsValue(Object) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- containsValue(Object) - Method in interface com.hazelcast.map.QueryCache
-  
- containsValue(boolean, Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-  
- containsValue(Object) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-  
- containsValue(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-  
- containsValue(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- containsValue(Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-  
- containsValue(Object) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
- containsValue(long) - Method in class com.hazelcast.util.collection.Long2LongHashMap
-  
- containsValue(Object) - Method in class com.hazelcast.util.collection.Long2LongHashMap
- containsValue(Object) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
- containsValue(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
- 
Returns true if this map maps one or more keys to the
 specified value. 
- ContainsValueOperation - Class in com.hazelcast.map.impl.operation
-  
- ContainsValueOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.ContainsValueOperation
-  
- ContainsValueOperation() - Constructor for class com.hazelcast.map.impl.operation.ContainsValueOperation
-  
- ContainsValueOperation - Class in com.hazelcast.replicatedmap.impl.operation
-  
- ContainsValueOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ContainsValueOperation
-  
- ContainsValueOperation(String, Data) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ContainsValueOperation
-  
- ContainsValueOperationFactory - Class in com.hazelcast.map.impl.operation
-  
- ContainsValueOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.ContainsValueOperationFactory
-  
- ContainsValueOperationFactory(String, Data) - Constructor for class com.hazelcast.map.impl.operation.ContainsValueOperationFactory
-  
- CONTENT_LENGTH - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
-  
- CONTENT_TYPE - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
-  
- CONTENT_TYPE_BINARY - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
-  
- CONTENT_TYPE_JSON - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
-  
- CONTENT_TYPE_PLAIN_TEXT - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
-  
- context - Variable in class com.hazelcast.client.util.ClientCancellableDelegatingFuture
-  
- Context<K,V> - Interface in com.hazelcast.mapreduce
- 
The Context interface is used for emitting keys and values to the intermediate working space of
 the MapReduce algorithm. 
- ContextMutexFactory - Class in com.hazelcast.util
- 
Utility class that provides reference-counted mutexes suitable for synchronization in the context of a supplied object. 
- ContextMutexFactory() - Constructor for class com.hazelcast.util.ContextMutexFactory
-  
- ContextMutexFactory.Mutex - Class in com.hazelcast.util
- 
Reference counted mutex, which will remove itself from the mutexMap when it is no longer referenced. 
- convert(Throwable) - Method in interface com.hazelcast.client.impl.exceptionconverters.ClientExceptionConverter
-  
- convert(Throwable) - Method in class com.hazelcast.client.impl.exceptionconverters.GenericClientExceptionConverter
-  
- convert(Throwable) - Method in class com.hazelcast.client.impl.exceptionconverters.JavaClientExceptionConverter
-  
- convert(Comparable) - Method in interface com.hazelcast.core.TypeConverter
- 
- convert(long, MemoryUnit) - Method in enum com.hazelcast.memory.MemoryUnit
-  
- convert(Map.Entry, Comparable, Comparable) - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
- 
Converts givenAttributeValue to the type of entryAttributeValue
 Good practice: do not invoke this method if entryAttributeValue == null 
- convert(Comparable) - Method in class com.hazelcast.query.impl.TypeConverters.BaseTypeConverter
-  
- convertEnumValue(Object) - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
-  
- convertToEventType(CacheEventType) - Static method in enum com.hazelcast.cache.impl.CacheEventType
- 
- convertToLazyEntryView(EntryView, SerializationService, MapMergePolicy) - Static method in class com.hazelcast.map.impl.EntryViews
-  
- convertToLetter(int) - Method in class com.hazelcast.util.PhoneHome
-  
- convertToObjectKeys(Collection) - Method in class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
-  
- convertVersionToString(int) - Static method in class com.hazelcast.internal.management.ManagementCenterIdentifier
-  
- copy(IntHashSet) - Method in class com.hazelcast.util.collection.IntHashSet
- copy(LongHashSet) - Method in class com.hazelcast.util.collection.LongHashSet
- copyCollections() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-  
- copyToHeapBuffer(ByteBuffer, ByteBuffer) - Static method in class com.hazelcast.nio.IOUtil
-  
- copyValuesTo(LocalMapStatsImpl) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
-  
- copyWithoutNulls(T[], T[]) - Static method in class com.hazelcast.util.collection.ArrayUtils
- 
Copy src array into destination and skip null values. 
- CoreService - Interface in com.hazelcast.spi
- 
Marker interface for core Hazelcast services. 
- count() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
- 
Returns an aggregation for counting all supplied values.
 This aggregation is similar to:
 
- COUNT - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- COUNT - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-  
- COUNT_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- COUNT_DOWN_LATCH_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-  
- COUNT_DOWN_LATCH_REPLICATION_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-  
- COUNT_DOWN_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-  
- COUNT_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- CountAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
- 
The predefined count aggregation. 
- CountAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.CountAggregation
-  
- countDown() - Method in class com.hazelcast.client.proxy.ClientCountDownLatchProxy
-  
- countDown() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
-  
- countDown() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
-  
- countDown(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-  
- countDown() - Method in interface com.hazelcast.core.ICountDownLatch
- 
Decrements the count of the latch, releasing all waiting threads if
 the count reaches zero. 
- countDown() - Method in class com.hazelcast.jmx.CountDownLatchMBean
-  
- countDownCompletionLatch(int) - Method in interface com.hazelcast.cache.impl.CacheSyncListenerCompleter
-  
- CountDownLatchAwaitMessageTask - Class in com.hazelcast.client.impl.protocol.task.countdownlatch
-  
- CountDownLatchAwaitMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchAwaitMessageTask
-  
- CountDownLatchBackupOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
-  
- CountDownLatchBackupOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
-  
- CountDownLatchBackupOperation(String, int) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
-  
- CountDownLatchContainer - Class in com.hazelcast.concurrent.countdownlatch
-  
- CountDownLatchContainer() - Constructor for class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
-  
- CountDownLatchContainer(String) - Constructor for class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
-  
- CountDownLatchCountDownMessageTask - Class in com.hazelcast.client.impl.protocol.task.countdownlatch
-  
- CountDownLatchCountDownMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchCountDownMessageTask
-  
- CountDownLatchDataSerializerHook - Class in com.hazelcast.concurrent.countdownlatch
-  
- CountDownLatchDataSerializerHook() - Constructor for class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-  
- CountDownLatchGetCountMessageTask - Class in com.hazelcast.client.impl.protocol.task.countdownlatch
-  
- CountDownLatchGetCountMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchGetCountMessageTask
-  
- CountDownLatchMBean - Class in com.hazelcast.jmx
- 
- CountDownLatchMBean(ICountDownLatch, ManagementService) - Constructor for class com.hazelcast.jmx.CountDownLatchMBean
-  
- CountDownLatchPermission - Class in com.hazelcast.security.permission
-  
- CountDownLatchPermission(String, String...) - Constructor for class com.hazelcast.security.permission.CountDownLatchPermission
-  
- CountDownLatchPortableHook - Class in com.hazelcast.concurrent.countdownlatch.client
-  
- CountDownLatchPortableHook() - Constructor for class com.hazelcast.concurrent.countdownlatch.client.CountDownLatchPortableHook
-  
- CountDownLatchProxy - Class in com.hazelcast.concurrent.countdownlatch
-  
- CountDownLatchProxy(String, NodeEngine) - Constructor for class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
-  
- CountDownLatchReplicationOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
-  
- CountDownLatchReplicationOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
-  
- CountDownLatchReplicationOperation(Collection<CountDownLatchContainer>) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
-  
- CountDownLatchService - Class in com.hazelcast.concurrent.countdownlatch
-  
- CountDownLatchService() - Constructor for class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-  
- CountDownLatchTrySetCountMessageTask - Class in com.hazelcast.client.impl.protocol.task.countdownlatch
-  
- CountDownLatchTrySetCountMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchTrySetCountMessageTask
-  
- CountDownOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
-  
- CountDownOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
-  
- CountDownOperation(String) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
-  
- CountDownRequest - Class in com.hazelcast.concurrent.countdownlatch.client
-  
- CountDownRequest() - Constructor for class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-  
- CountDownRequest(String) - Constructor for class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-  
- Counter - Interface in com.hazelcast.util.counters
- 
A Counter keeps track of a long value. 
- countInternal(Data) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-  
- CountOperation - Class in com.hazelcast.multimap.impl.operations
-  
- CountOperation() - Constructor for class com.hazelcast.multimap.impl.operations.CountOperation
-  
- CountOperation(String, Data) - Constructor for class com.hazelcast.multimap.impl.operations.CountOperation
-  
- CountRequest - Class in com.hazelcast.multimap.impl.client
-  
- CountRequest() - Constructor for class com.hazelcast.multimap.impl.client.CountRequest
-  
- CountRequest(String, Data, long) - Constructor for class com.hazelcast.multimap.impl.client.CountRequest
-  
- CPP - Static variable in class com.hazelcast.client.ClientTypes
- 
CPP client protocol id 
- create(int) - Method in class com.hazelcast.client.impl.client.ClientPortableFactory
-  
- create() - Static method in class com.hazelcast.client.impl.protocol.ClientMessage
-  
- create(ClientMessage, Connection) - Method in interface com.hazelcast.client.impl.protocol.MessageTaskFactory
-  
- create(ClientMessage, Connection) - Method in class com.hazelcast.client.impl.protocol.MessageTaskFactoryImpl
-  
- create(String) - Method in interface com.hazelcast.client.spi.ClientProxyFactory
-  
- create(int) - Method in class com.hazelcast.cluster.impl.ClusterDataSerializerHook.ClusterDataSerializerFactoryImpl
-  
- create(String, QueueStoreConfig, SerializationService) - Static method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
- 
- create(Node) - Static method in class com.hazelcast.instance.NodeExtensionFactory
-  
- create(int) - Method in class com.hazelcast.internal.serialization.impl.ArrayDataSerializableFactory
-  
- create(SerializationService) - Method in interface com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolFactory
-  
- create(SerializationService) - Method in class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolFactoryImpl
-  
- create(int) - Method in interface com.hazelcast.nio.serialization.DataSerializableFactory
- 
Creates an IdentifiedDataSerializable instance using given type id 
- create(int) - Method in interface com.hazelcast.nio.serialization.PortableFactory
- 
Creates a Portable instance using given class id 
- CREATE - Static variable in class com.hazelcast.security.permission.InstancePermission
-  
- CREATE - Static variable in class com.hazelcast.transaction.client.ClientTxnPortableHook
-  
- CREATE_ALLOWED_DURING_PASSIVE_STATE_TX_BACKUP_LOG - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
-  
- CREATE_CONFIG - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- CREATE_CONFIG - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- CREATE_PROXY - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-  
- CREATE_TX_BACKUP_LOG - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
-  
- CREATE_XA - Static variable in class com.hazelcast.transaction.client.ClientTxnPortableHook
-  
- createAddressPicker(Node) - Method in class com.hazelcast.instance.DefaultNodeContext
-  
- createAddressPicker(Node) - Method in interface com.hazelcast.instance.NodeContext
-  
- createAdHocRunner() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationRunnerFactory
- 
Creates an ad hoc generic OperationRunner. 
- createAllowedDuringPassiveStateBackupLog(String, String) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-  
- CreateAllowedDuringPassiveStateTxBackupLogOperation - Class in com.hazelcast.transaction.impl.operations
-  
- CreateAllowedDuringPassiveStateTxBackupLogOperation() - Constructor for class com.hazelcast.transaction.impl.operations.CreateAllowedDuringPassiveStateTxBackupLogOperation
-  
- CreateAllowedDuringPassiveStateTxBackupLogOperation(String, String) - Constructor for class com.hazelcast.transaction.impl.operations.CreateAllowedDuringPassiveStateTxBackupLogOperation
-  
- createAndFillBeanBuilder(Node, Class, String, BeanDefinitionBuilder, String...) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
-  
- createAndFillListedBean(Node, Class, String, ManagedMap, String...) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
-  
- createAndPopulateEvictionCriteriaArray(RecordStore, EvictionPolicy) - Method in class com.hazelcast.map.impl.eviction.EvictorImpl
-  
- createBackupEntryProcessor() - Method in interface com.hazelcast.cache.BackupAwareEntryProcessor
- 
Either creates a new, specialized EntryProcessorto be executed on the backup-partition, or returns
 
- createBackupLog(String, String) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-  
- createBaseEventContext(CacheEventType, Data, Data, long, String, int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
-  
- createBeanBuilder(Class) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
-  
- createBoundedWriteBehindQueue(int, AtomicInteger) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueues
-  
- createCache(String, C) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- createCacheCompleteEvent(int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
-  
- createCacheCompleteEvent(Data, int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
-  
- createCacheCompleteEvent(Data, long, String, int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
-  
- createCacheConfig(String, C) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- createCacheCreatedEvent(Data, Data, long, String, int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
-  
- createCacheDataRecord(Data, long, long) - Method in class com.hazelcast.cache.impl.record.CacheRecordFactory
-  
- createCacheEntryProcessorEntry(Data, R, long, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- createCacheEntryProcessorEntry(Data, CacheRecord, long, int) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-  
- createCacheExpiredEvent(Data, Data, long, String, int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
-  
- createCacheMaxSizeChecker(int, EvictionConfig.MaxSizePolicy) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- createCacheMaxSizeChecker(int, EvictionConfig.MaxSizePolicy) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-  
- createCacheObjectRecord(Object, long, long) - Method in class com.hazelcast.cache.impl.record.CacheRecordFactory
-  
- createCacheProxy(CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- createCacheProxy(CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-  
- createCacheProxy(CacheConfig<K, V>) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
-  
- createCacheRecordFactory() - Method in class com.hazelcast.cache.impl.CacheRecordStore
-  
- createCacheRemovedEvent(Data, Data, long, String, int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
-  
- createCacheRemovedEvent(Data) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
-  
- createCacheStatIfAbsent(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- createCacheStatIfAbsent(String) - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- createCacheUpdatedEvent(Data, Data, Data, long, long, long, String, int) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
-  
- createCacheUpdatedEvent(Data, Data, Data, long, long, long) - Static method in class com.hazelcast.cache.impl.CacheEventContextUtil
-  
- createCachingProvider(HazelcastInstance) - Static method in class com.hazelcast.cache.impl.HazelcastServerCachingProvider
- 
Helper method for creating caching provider for testing, etc. 
- createCachingProvider(HazelcastInstance) - Static method in class com.hazelcast.client.cache.impl.HazelcastClientCachingProvider
- 
Helper method for creating caching provider for testing etc 
- createClearOperation(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createClearOperation(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createClearOperation(String) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createClearOperationFactory() - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-  
- createClearOperationFactory() - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-  
- createClearOperationFactory(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createClearOperationFactory(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createClearOperationFactory(String) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createClientLoginContext(Credentials) - Method in interface com.hazelcast.security.SecurityContext
- 
- createClientUuid(Address) - Static method in class com.hazelcast.util.UuidUtil
- 
Creates a new client  UUID string,
 based on a cryptographically weak pseudo random number generator. 
- createClusterUuid() - Static method in class com.hazelcast.util.UuidUtil
- 
Creates a new cluster  UUID string,
 based on a cryptographically weak pseudo random number generator. 
- createCollection(MultiMapConfig.ValueCollectionType) - Static method in class com.hazelcast.multimap.impl.ValueCollectionFactory
- 
- createCollection(MultiMapConfig.ValueCollectionType, int) - Static method in class com.hazelcast.multimap.impl.ValueCollectionFactory
- 
- createCollection(Collection) - Static method in class com.hazelcast.multimap.impl.ValueCollectionFactory
- 
- createConfig(String, CacheConfig<K, V>, boolean, boolean) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- createConfig(String, CacheConfig<K, V>, boolean, boolean) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-  
- createConfig(String, CacheConfig<K, V>, boolean, boolean) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
-  
- createConfigCheck() - Method in class com.hazelcast.instance.Node
-  
- createConfigOnPartition(CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- createConfigOnPartition(CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-  
- createConfigOnPartition(CacheConfig<K, V>) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
-  
- createConnectionFactory() - Method in class com.hazelcast.jca.ManagedConnectionFactoryImpl
-  
- createConnectionFactory(ConnectionManager) - Method in class com.hazelcast.jca.ManagedConnectionFactoryImpl
-  
- createConnectionManager(ClientConfig, HazelcastClientInstanceImpl, DiscoveryService) - Method in interface com.hazelcast.client.impl.ClientConnectionManagerFactory
-  
- createConnectionManager(ClientConfig, HazelcastClientInstanceImpl, DiscoveryService) - Method in class com.hazelcast.client.impl.DefaultClientConnectionManagerFactory
-  
- createConnectionManager(Node, ServerSocketChannel) - Method in class com.hazelcast.instance.DefaultNodeContext
-  
- createConnectionManager(Node, ServerSocketChannel) - Method in interface com.hazelcast.instance.NodeContext
-  
- createContainsKeyOperation(Data) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-  
- createContainsKeyOperation(Data) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-  
- createContainsKeyOperation(String, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createContainsKeyOperation(String, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createContainsKeyOperation(String, Data) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createContainsValueOperationFactory(String, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createContainsValueOperationFactory(String, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createContainsValueOperationFactory(String, Data) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createCopy(T[]) - Static method in class com.hazelcast.util.collection.ArrayUtils
- 
Create copy of the src array. 
- createCreateTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.AllowedDuringPassiveStateTransactionImpl
-  
- createCreateTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-  
- createDefault(K, V, long, int) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntries
-  
- createDefaultEntryView(Data, Data, CacheRecord) - Static method in class com.hazelcast.cache.impl.CacheEntryViews
- 
- createDefaultWriteBehindQueue() - Static method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueues
-  
- createDeleteOperation(String, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createDeleteOperation(String, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createDeleteOperation(String, Data) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createDeleteOperation(String, Data) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-  
- createDistributedObject(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- createDistributedObject(String) - Method in class com.hazelcast.collection.impl.list.ListService
-  
- createDistributedObject(String) - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- createDistributedObject(String) - Method in class com.hazelcast.collection.impl.set.SetService
-  
- createDistributedObject(String) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-  
- createDistributedObject(String) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-  
- createDistributedObject(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-  
- createDistributedObject(String) - Method in class com.hazelcast.concurrent.idgen.IdGeneratorService
-  
- createDistributedObject(String) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-  
- createDistributedObject(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-  
- createDistributedObject(String) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-  
- createDistributedObject(String) - Method in class com.hazelcast.map.impl.MapService
-  
- createDistributedObject(String) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-  
- createDistributedObject(String) - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- createDistributedObject(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- createDistributedObject(String) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-  
- createDistributedObject(String) - Method in interface com.hazelcast.spi.RemoteService
- 
Creates a distributed object. 
- createDistributedObject(String) - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicService
-  
- createDistributedObject(String) - Method in class com.hazelcast.topic.impl.TopicService
-  
- createDistributedObject(String) - Method in class com.hazelcast.transaction.impl.xa.XAService
-  
- createEmptyResponseHandler() - Static method in class com.hazelcast.spi.impl.OperationResponseHandlerFactory
-  
- createEntryCountResolver() - Static method in class com.hazelcast.cache.impl.CacheEntryCountResolver
-  
- createEntryCountResolver(CacheContext) - Static method in class com.hazelcast.cache.impl.CacheEntryCountResolver
-  
- createEntryOperation(String, Data, EntryProcessor) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createEntryOperation(String, Data, EntryProcessor) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createEntryOperation(String, Data, EntryProcessor) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createEntryOperation(String, Data, EntryProcessor) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-  
- createEntryProcessorOperation(Data, Integer, EntryProcessor, Object...) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-  
- createEntryProcessorOperation(Data, Integer, EntryProcessor, Object...) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-  
- createEntryView(Data, Data, CacheRecord, CacheEntryViews.CacheEntryViewType) - Static method in class com.hazelcast.cache.impl.CacheEntryViews
- 
- createErrorLoggingResponseHandler(ILogger) - Static method in class com.hazelcast.spi.impl.OperationResponseHandlerFactory
-  
- createEvictAllOperation(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createEvictAllOperation(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createEvictAllOperation(String) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createEvictAllOperationFactory(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createEvictAllOperationFactory(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createEvictAllOperationFactory(String) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createEvictionChecker(EvictionConfig) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- createEvictionChecker(NearCacheConfig) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- createEvictionPolicyEvaluator(EvictionConfig) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- createEvictionPolicyEvaluator(EvictionConfig) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- createEvictionStrategy(EvictionConfig) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- createEvictionStrategy(EvictionConfig) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- createEvictOperation(String, Data, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createEvictOperation(String, Data, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createEvictOperation(String, Data, boolean) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createException(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.ClientExceptionFactory
-  
- createExceptionMessage(Throwable) - Method in class com.hazelcast.client.impl.protocol.ClientExceptionFactory
-  
- createExpirationTask() - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache
-  
- createExtensionServices() - Method in class com.hazelcast.instance.DefaultNodeExtension
-  
- createExtensionServices() - Method in interface com.hazelcast.instance.NodeExtension
- 
Creates additional extension services, which will be registered by
 service manager during start-up. 
- createFactory() - Method in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.cache.impl.CachePortableHook
-  
- createFactory() - Method in class com.hazelcast.client.impl.client.ClientPortableHook
-  
- createFactory() - Method in class com.hazelcast.client.impl.ClientDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.cluster.impl.ClusterDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.collection.impl.collection.CollectionPortableHook
-  
- createFactory() - Method in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.collection.impl.queue.QueuePortableHook
-  
- createFactory() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.concurrent.atomiclong.client.AtomicLongPortableHook
-  
- createFactory() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.concurrent.atomicreference.client.AtomicReferencePortableHook
-  
- createFactory() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownLatchPortableHook
-  
- createFactory() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.concurrent.lock.client.LockPortableHook
-  
- createFactory() - Method in class com.hazelcast.concurrent.lock.LockDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.concurrent.semaphore.client.SemaphorePortableHook
-  
- createFactory() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.executor.impl.ExecutorPortableHook
-  
- createFactory() - Method in class com.hazelcast.hibernate.serialization.HibernateDataSerializerHook
-  
- createFactory() - Method in interface com.hazelcast.internal.serialization.DataSerializerHook
-  
- createFactory() - Method in interface com.hazelcast.internal.serialization.PortableHook
-  
- createFactory() - Method in class com.hazelcast.map.impl.MapDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.map.impl.MapPortableHook
-  
- createFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.mapreduce.impl.MapReducePortableHook
-  
- createFactory() - Method in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.multimap.impl.MultiMapPortableHook
-  
- createFactory() - Method in class com.hazelcast.partition.PartitionDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.partition.PartitionPortableHook
-  
- createFactory() - Method in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-  
- createFactory() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
-  
- createFactory() - Method in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.spi.impl.SpiDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.spi.impl.SpiPortableHook
-  
- createFactory() - Method in class com.hazelcast.topic.impl.TopicDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.topic.impl.TopicPortableHook
-  
- createFactory() - Method in class com.hazelcast.transaction.client.ClientTxnPortableHook
-  
- createFactory() - Method in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.wan.impl.WanDataSerializerHook
-  
- createFactory() - Method in class com.hazelcast.web.WebDataSerializerHook
-  
- createForDecode(ClientProtocolBuffer, int) - Static method in class com.hazelcast.client.impl.protocol.ClientMessage
-  
- createForEncode(int) - Static method in class com.hazelcast.client.impl.protocol.ClientMessage
-  
- createForEncode(ClientProtocolBuffer, int) - Static method in class com.hazelcast.client.impl.protocol.ClientMessage
-  
- createFormattedCredential() - Method in class com.hazelcast.aws.security.EC2RequestSigner
-  
- createGenericRunner() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationRunnerFactory
- 
Creates an OperationRunner to execute generic Operations. 
- createGetAllOperationFactory(Set<Data>, ExpiryPolicy) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-  
- createGetAllOperationFactory(Set<Data>, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-  
- createGetAllOperationFactory(String, List<Data>) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createGetAllOperationFactory(String, List<Data>) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createGetAllOperationFactory(String, List<Data>) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createGetAndRemoveOperation(Data, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-  
- createGetAndRemoveOperation(Data, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-  
- createGetAndReplaceOperation(Data, Data, ExpiryPolicy, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-  
- createGetAndReplaceOperation(Data, Data, ExpiryPolicy, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-  
- createGetEntryViewOperation(String, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createGetEntryViewOperation(String, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createGetEntryViewOperation(String, Data) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createGetOperation(Data, ExpiryPolicy) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-  
- createGetOperation(Data, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-  
- createGetOperation(String, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createGetOperation(String, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createGetOperation(String, Data) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createGetter(Object, String) - Static method in class com.hazelcast.query.impl.getters.ReflectionHelper
-  
- createHashMap(int) - Static method in class com.hazelcast.util.MapUtil
- 
Utility method that creates an  HashMap with its initialCapacity calculated
 to minimize rehash operations 
- createHazelcastCacheManager(URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-  
- createHazelcastCacheManager(URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.impl.HazelcastServerCachingProvider
-  
- createHazelcastCacheManager(URI, ClassLoader, Properties) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCachingProvider
-  
- createHazelcastHttpSession(String, HttpSession, boolean) - Method in class com.hazelcast.web.WebFilter
- 
HazelcastHttpSession instancecreation is split off to a separate method to allow subclasses to return a
 customized / extended version ofHazelcastHttpSession.
 
- createInput(Data, SerializationService) - Method in interface com.hazelcast.internal.serialization.InputOutputFactory
-  
- createInput(byte[], SerializationService) - Method in interface com.hazelcast.internal.serialization.InputOutputFactory
-  
- createInputOutputFactory() - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- createInstanceLoader(Properties) - Static method in class com.hazelcast.hibernate.instance.HazelcastInstanceFactory
-  
- createInteraction() - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- createInternalMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.ConfigMemberGroupFactory
-  
- createInternalMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.HostAwareMemberGroupFactory
-  
- createInvocationBuilder(String, Operation, int) - Method in class com.hazelcast.client.impl.client.InvocationClientRequest
-  
- createInvocationBuilder(String, Operation, Address) - Method in class com.hazelcast.client.impl.client.InvocationClientRequest
-  
- createInvocationBuilder() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.AbstractExecutorServiceCancelMessageTask
-  
- createInvocationBuilder() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnAddressMessageTask
-  
- createInvocationBuilder() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnPartitionMessageTask
-  
- createInvocationBuilder(String, Operation, int) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- createInvocationBuilder(String, Operation, Address) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- createInvocationBuilder(String, Operation, int) - Method in interface com.hazelcast.spi.OperationService
-  
- createInvocationBuilder(String, Operation, Address) - Method in interface com.hazelcast.spi.OperationService
-  
- createJobProcessInformation(JobTaskConfiguration, JobSupervisor) - Static method in class com.hazelcast.mapreduce.impl.MapReduceUtil
-  
- createJobSupervisor(JobTaskConfiguration) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-  
- createJoiner(Node) - Method in class com.hazelcast.instance.DefaultNodeContext
-  
- createJoiner(Node) - Method in interface com.hazelcast.instance.NodeContext
-  
- createJoinRequest(boolean) - Method in class com.hazelcast.instance.Node
-  
- createKeyIteratorOperation(int, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-  
- createKeyIteratorOperation(int, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-  
- createLazyEntryView(Data, Data, CacheRecord) - Static method in class com.hazelcast.cache.impl.CacheEntryViews
- 
- createLazyEntryView(K, V, Record, SerializationService, MapMergePolicy) - Static method in class com.hazelcast.map.impl.EntryViews
-  
- createListenerAdapter(Object) - Static method in class com.hazelcast.map.impl.ListenerAdapters
-  
- createListenerAdapters(EntryListener) - Static method in class com.hazelcast.map.impl.EntryListenerAdaptors
- 
- createListenerAdapters(MapListener) - Static method in class com.hazelcast.map.impl.MapListenerAdaptors
- 
- createLoadAllOperation(String, List<Data>, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createLoadAllOperation(String, List<Data>, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createLoadAllOperation(String, List<Data>, boolean) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createLoadAllOperationFactory(Set<Data>, boolean) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-  
- createLoadAllOperationFactory(Set<Data>, boolean) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-  
- createLoadAllOperationFactory(String, List<Data>, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createLoadAllOperationFactory(String, List<Data>, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createLoadAllOperationFactory(String, List<Data>, boolean) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createLoadMapOperation(String, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createLoadMapOperation(String, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createLoadMapOperation(String, boolean) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createLocalMapStats(String) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
-  
- createLocalQueueStats(String, int) - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- createLocalQueueStats(String) - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- createLockStore(int, ObjectNamespace) - Method in interface com.hazelcast.concurrent.lock.LockService
-  
- createLockStore(int, ObjectNamespace) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-  
- createLogger(String) - Method in class com.hazelcast.logging.Log4j2Factory
-  
- createLogger(String) - Method in class com.hazelcast.logging.Log4jFactory
-  
- createLogger(String) - Method in class com.hazelcast.logging.LoggerFactorySupport
-  
- createLogger(String) - Method in class com.hazelcast.logging.Slf4jFactory
-  
- createLogger(String) - Method in class com.hazelcast.logging.StandardLoggerFactory
-  
- createManagedConnection(Subject, ConnectionRequestInfo) - Method in class com.hazelcast.jca.ManagedConnectionFactoryImpl
-  
- createMapFlushOperation(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createMapFlushOperation(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createMapFlushOperation(String) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createMapFlushOperationFactory(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createMapFlushOperationFactory(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createMapFlushOperationFactory(String) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createMapService() - Method in interface com.hazelcast.map.impl.MapServiceFactory
- 
- createMapSizeEstimator(InMemoryFormat) - Static method in class com.hazelcast.map.impl.SizeEstimators
-  
- createMapSizeOperationFactory(String) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createMapSizeOperationFactory(String) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createMapSizeOperationFactory(String) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createMapStoreContext(MapContainer) - Static method in class com.hazelcast.map.impl.mapstore.MapStoreContextFactory
-  
- createMemberGroups(Collection<? extends Member>) - Method in interface com.hazelcast.partition.membergroup.MemberGroupFactory
-  
- createMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroupFactory
-  
- createMemberLoginContext(Credentials) - Method in interface com.hazelcast.security.SecurityContext
- 
- createMemberUuid(Address) - Static method in class com.hazelcast.util.UuidUtil
- 
Creates a new member  UUID string,
 based on a cryptographically weak pseudo random number generator. 
- createMergeOperation(String, Data, EntryView<Data, Data>, MapMergePolicy, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createMergeOperation(String, Data, EntryView<Data, Data>, MapMergePolicy, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createMergeOperation(String, Data, EntryView<Data, Data>, MapMergePolicy, boolean) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createMessage(Object, Object, Object) - Method in class com.hazelcast.hibernate.local.LocalRegionCache
-  
- createMessage(Object, Object, Object) - Method in class com.hazelcast.hibernate.local.TimestampsRegionCache
-  
- createMessageListener() - Method in class com.hazelcast.hibernate.local.LocalRegionCache
-  
- createMessageTaskFactory() - Method in class com.hazelcast.instance.DefaultNodeExtension
-  
- createMessageTaskFactory() - Method in interface com.hazelcast.instance.NodeExtension
- 
Creates factory method that creates server side client message handlers 
- createMulticastService(Address, Node, Config, ILogger) - Static method in class com.hazelcast.cluster.impl.MulticastService
-  
- createMultipleEntryOperationFactory(String, Set<Data>, EntryProcessor) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createMultipleEntryOperationFactory(String, Set<Data>, EntryProcessor) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createMultipleEntryOperationFactory(String, Set<Data>, EntryProcessor) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createMultipleEntryOperationFactory(String, Set<Data>, EntryProcessor) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-  
- createMultiResultSet() - Method in class com.hazelcast.query.impl.BaseIndexStore
-  
- createNearCache(String, NearCacheConfig, NearCacheContext) - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCacheManager
-  
- createNearCacheInvalidator(MapServiceContext) - Method in class com.hazelcast.map.impl.nearcache.NearCacheProvider
-  
- createNearCacheManager() - Method in interface com.hazelcast.client.ClientExtension
- 
- createNearCacheManager() - Method in class com.hazelcast.client.impl.DefaultClientExtension
-  
- createNearCacheMaxSizeChecker(EvictionConfig, NearCacheConfig, NearCacheContext) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- createNearCacheMaxSizeChecker(EvictionConfig, NearCacheConfig, NearCacheContext) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.BaseHeapNearCacheRecordStore
-  
- createNearCacheRecordMap(NearCacheConfig, NearCacheContext) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- createNearCacheRecordMap(NearCacheConfig, NearCacheContext) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.BaseHeapNearCacheRecordStore
-  
- createNearCacheRecordStore(NearCacheConfig, NearCacheContext) - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache
-  
- createNearCacheSizeEstimator(NearCacheConfig) - Static method in class com.hazelcast.map.impl.SizeEstimators
-  
- createNew(String) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-  
- createNew(K) - Method in interface com.hazelcast.util.ConstructorFunction
-  
- createNewRecordStore(String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- createNewRecordStore(String, int) - Method in class com.hazelcast.cache.impl.CacheService
-  
- createNewSession(WebFilter.RequestWrapper, String) - Method in class com.hazelcast.web.spring.SpringAwareWebFilter
-  
- createNewSession(WebFilter.RequestWrapper, String) - Method in class com.hazelcast.web.WebFilter
-  
- createNodeExtension(Node) - Method in class com.hazelcast.instance.DefaultNodeContext
-  
- createNodeExtension(Node) - Method in interface com.hazelcast.instance.NodeContext
-  
- createNullEntryView(K) - Static method in class com.hazelcast.map.impl.EntryViews
- 
Creates a null entry view that has only key and no value. 
- createObjectDataInput(byte[]) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- createObjectDataInput(Data) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- createObjectDataInput(byte[]) - Method in interface com.hazelcast.internal.serialization.SerializationService
-  
- createObjectDataInput(Data) - Method in interface com.hazelcast.internal.serialization.SerializationService
-  
- createObjectDataInputStream(InputStream, SerializationService) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
-  
- createObjectDataOutput(int) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- createObjectDataOutput() - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- createObjectDataOutput(int) - Method in interface com.hazelcast.internal.serialization.SerializationService
-  
- createObjectDataOutput() - Method in interface com.hazelcast.internal.serialization.SerializationService
-  
- createObjectDataOutputStream(OutputStream, SerializationService) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
-  
- createObjectName(String, String) - Method in class com.hazelcast.jmx.ManagementService
-  
- createOperation() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
-  
- createOperation() - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
-  
- createOperation() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
-  
- createOperation() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
-  
- createOperation() - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
-  
- createOperation() - Method in class com.hazelcast.client.impl.operations.OperationFactoryWrapper
-  
- createOperation() - Method in class com.hazelcast.map.impl.operation.AddIndexOperationFactory
-  
- createOperation() - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperationFactory
-  
- createOperation() - Method in class com.hazelcast.map.impl.operation.ClearOperationFactory
-  
- createOperation() - Method in class com.hazelcast.map.impl.operation.ContainsValueOperationFactory
-  
- createOperation() - Method in class com.hazelcast.map.impl.operation.EvictAllOperationFactory
-  
- createOperation() - Method in class com.hazelcast.map.impl.operation.IsEmptyOperationFactory
-  
- createOperation() - Method in class com.hazelcast.map.impl.operation.LoadStatusOperationFactory
-  
- createOperation() - Method in class com.hazelcast.map.impl.operation.MapFlushOperationFactory
-  
- createOperation() - Method in class com.hazelcast.map.impl.operation.MapGetAllOperationFactory
-  
- createOperation() - Method in class com.hazelcast.map.impl.operation.MapLoadAllOperationFactory
-  
- createOperation() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperationFactory
-  
- createOperation() - Method in class com.hazelcast.map.impl.operation.PartitionCheckIfLoadedOperationFactory
-  
- createOperation() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperationFactory
-  
- createOperation() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperationFactory
-  
- createOperation() - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperationFactory
-  
- createOperation() - Method in class com.hazelcast.map.impl.operation.SizeOperationFactory
-  
- createOperation() - Method in class com.hazelcast.mapreduce.impl.operation.GetResultOperationFactory
-  
- createOperation() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
-  
- createOperation() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperationFactory
-  
- createOperation() - Method in class com.hazelcast.replicatedmap.impl.operation.PutAllOperationFactory
-  
- createOperation() - Method in class com.hazelcast.spi.impl.BinaryOperationFactory
-  
- createOperation() - Method in interface com.hazelcast.spi.OperationFactory
- 
Creates the operation. 
- createOperation() - Method in class com.hazelcast.transaction.impl.xa.operations.CollectRemoteTransactionsOperationFactory
-  
- createOperationFactory() - Method in class com.hazelcast.cache.impl.client.CacheClearRequest
-  
- createOperationFactory() - Method in class com.hazelcast.cache.impl.client.CacheGetAllRequest
-  
- createOperationFactory() - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-  
- createOperationFactory() - Method in class com.hazelcast.cache.impl.client.CacheSizeRequest
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.client.AllPartitionsClientRequest
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.client.MultiPartitionClientRequest
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.client.MultiTargetClientRequest
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.AbstractAllPartitionsMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMultiPartitionMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMultiTargetMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAllMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheSizeMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddIndexMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddInterceptorMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsValueMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictAllMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnAllKeysMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeysMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteWithPredicateMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveInterceptorMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSizeMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapClearMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsValueMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XACollectTransactionsMessageTask
-  
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapAddIndexRequest
-  
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-  
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapClearRequest
-  
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapContainsValueRequest
-  
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapEvictAllRequest
-  
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-  
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-  
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-  
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapFlushRequest
-  
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapIsEmptyRequest
-  
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-  
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-  
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapSizeRequest
-  
- createOperationFactory() - Method in class com.hazelcast.multimap.impl.client.ClearRequest
-  
- createOperationFactory() - Method in class com.hazelcast.multimap.impl.client.ContainsRequest
-  
- createOperationFactory() - Method in class com.hazelcast.multimap.impl.client.EntrySetRequest
-  
- createOperationFactory() - Method in class com.hazelcast.multimap.impl.client.KeySetRequest
-  
- createOperationFactory() - Method in class com.hazelcast.multimap.impl.client.SizeRequest
-  
- createOperationFactory() - Method in class com.hazelcast.multimap.impl.client.ValuesRequest
-  
- createOperationFactory() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapClearRequest
-  
- createOperationFactory() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-  
- createOperationFactory() - Method in class com.hazelcast.transaction.client.CollectXATransactionsRequest
-  
- createOperationProvider(String, InMemoryFormat) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- createOperationProvider(String, InMemoryFormat) - Method in class com.hazelcast.cache.impl.CacheService
-  
- createOutput(int, SerializationService) - Method in interface com.hazelcast.internal.serialization.InputOutputFactory
-  
- createPartitionRunner(int) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationRunnerFactory
- 
Creates an OperationRunner for a given partition. 
- createPartitionState() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- createPartitionWideEntryOperationFactory(String, EntryProcessor) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createPartitionWideEntryOperationFactory(String, EntryProcessor) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createPartitionWideEntryOperationFactory(String, EntryProcessor) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createPartitionWideEntryOperationFactory(String, EntryProcessor) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-  
- createPartitionWideEntryWithPredicateOperationFactory(String, EntryProcessor, Predicate) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createPartitionWideEntryWithPredicateOperationFactory(String, EntryProcessor, Predicate) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createPartitionWideEntryWithPredicateOperationFactory(String, EntryProcessor, Predicate) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createPartitionWideEntryWithPredicateOperationFactory(String, EntryProcessor, Predicate) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-  
- createPortableReader(Data) - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1
-  
- createPortableReader(Data) - Method in interface com.hazelcast.internal.serialization.SerializationService
-  
- createProperties() - Method in class com.hazelcast.client.config.ClientProperties
-  
- createProperties() - Method in class com.hazelcast.instance.GroupProperties
-  
- createProperties() - Method in class com.hazelcast.instance.HazelcastProperties
- 
Created the properties array. 
- createProxy(String, boolean, boolean) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyRegistry
- 
Creates a DistributedObject proxy if it is not created yet 
- CreateProxyMessageTask - Class in com.hazelcast.client.impl.protocol.task
-  
- CreateProxyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
-  
- createPurgeTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.AllowedDuringPassiveStateTransactionImpl
-  
- createPurgeTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-  
- createPutAllOperation(List<Map.Entry<Data, Data>>, ExpiryPolicy, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-  
- createPutAllOperation(List<Map.Entry<Data, Data>>, ExpiryPolicy, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-  
- createPutAllOperation(String, MapEntries, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createPutAllOperation(String, MapEntries, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createPutAllOperation(String, MapEntries, boolean) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createPutAllOperation(String, MapEntries, boolean) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-  
- createPutAllOperationFuture(String, MapEntries, int) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- createPutFromLoadAllOperation(String, List<Data>) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createPutFromLoadAllOperation(String, List<Data>) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createPutFromLoadAllOperation(String, List<Data>) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createPutFromLoadAllOperation(String, List<Data>) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-  
- createPutIfAbsentOperation(Data, Data, ExpiryPolicy, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-  
- createPutIfAbsentOperation(Data, Data, ExpiryPolicy, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-  
- createPutIfAbsentOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createPutIfAbsentOperation(String, Data, Data, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createPutIfAbsentOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createPutIfAbsentOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-  
- createPutOperation(Data, Data, ExpiryPolicy, boolean, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-  
- createPutOperation(Data, Data, ExpiryPolicy, boolean, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-  
- createPutOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createPutOperation(String, Data, Data, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createPutOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createPutOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-  
- createPutTransientOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createPutTransientOperation(String, Data, Data, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createPutTransientOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createPutTransientOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-  
- createReadHandler(TcpIpConnection, IOService) - Method in class com.hazelcast.instance.DefaultNodeExtension
-  
- createReadHandler(TcpIpConnection, IOService) - Method in interface com.hazelcast.instance.NodeExtension
- 
Creates a ReadHandler for given Connection instance. 
- createReadHandler(TcpIpConnection) - Method in interface com.hazelcast.nio.IOService
-  
- createReadHandler(TcpIpConnection) - Method in class com.hazelcast.nio.NodeIOService
-  
- createRecord(Object, long, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- createRecord(long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- createRecord(Object, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- createRecord(Data, Object, long, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- createRecord(Data, Object, long, long, boolean, int, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- createRecord(Object, long, long) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-  
- createRecord(Object, long, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- createRecordCacheMap() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- createRecordCacheMap() - Method in class com.hazelcast.cache.impl.CacheRecordStore
-  
- createRecordStore(MapContainer, int, MapKeyLoader) - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- createRecordWithExpiry(Data, Object, long, long, boolean, int, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- createRecordWithExpiry(Data, Object, long, long, boolean, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- createRecordWithExpiry(Data, Object, ExpiryPolicy, long, boolean, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- createRecordWithExpiry(Data, Object, ExpiryPolicy, long, boolean, int, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- createRemoveAllOperationFactory(Set<Data>, Integer) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-  
- createRemoveAllOperationFactory(Set<Data>, Integer) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-  
- createRemoveIfSameOperation(String, Data, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createRemoveIfSameOperation(String, Data, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createRemoveIfSameOperation(String, Data, Data) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createRemoveIfSameOperation(String, Data, Data) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-  
- createRemoveOperation(Data, Data, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-  
- createRemoveOperation(Data, Data, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-  
- createRemoveOperation(String, Data, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createRemoveOperation(String, Data, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createRemoveOperation(String, Data, boolean) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createRemoveOperation(String, Data, boolean) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-  
- createReplaceIfSameOperation(String, Data, Data, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createReplaceIfSameOperation(String, Data, Data, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createReplaceIfSameOperation(String, Data, Data, Data) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createReplaceIfSameOperation(String, Data, Data, Data) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-  
- createReplaceOperation(Data, Data, Data, ExpiryPolicy, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-  
- createReplaceOperation(Data, Data, Data, ExpiryPolicy, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-  
- createReplaceOperation(String, Data, Data) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createReplaceOperation(String, Data, Data) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createReplaceOperation(String, Data, Data) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createReplaceOperation(String, Data, Data) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-  
- createReplicatedMapStats(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- createReplicateTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.AllowedDuringPassiveStateTransactionImpl
-  
- createReplicateTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-  
- createRollbackTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.AllowedDuringPassiveStateTransactionImpl
-  
- createRollbackTxBackupLogOperation() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-  
- createSamplingEntry(K, V) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.HeapNearCacheRecordMap
-  
- createSamplingEntry(Data, CacheRecord) - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap
-  
- createSamplingEntry(K, V) - Method in class com.hazelcast.util.SampleableConcurrentHashMap
-  
- createSecureCallable(Subject, Callable<V>) - Method in interface com.hazelcast.security.SecurityContext
- 
Creates secure callable that runs in a sandbox. 
- createSerializationService(byte) - Method in interface com.hazelcast.client.ClientExtension
- 
- createSerializationService(byte) - Method in class com.hazelcast.client.impl.DefaultClientExtension
-  
- createSerializationService() - Method in class com.hazelcast.instance.DefaultNodeExtension
-  
- createSerializationService() - Method in interface com.hazelcast.instance.NodeExtension
- 
Creates a SerializationService instance to be used by this Node. 
- createSerializationService(InputOutputFactory) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- createSerializer() - Method in class com.hazelcast.hibernate.serialization.Hibernate3CacheEntrySerializerHook
-  
- createSerializer() - Method in class com.hazelcast.hibernate.serialization.Hibernate3CacheKeySerializerHook
-  
- createSerializer() - Method in class com.hazelcast.hibernate.serialization.Hibernate4CacheEntrySerializerHook
-  
- createSerializer() - Method in class com.hazelcast.hibernate.serialization.Hibernate4CacheKeySerializerHook
-  
- createSerializer() - Method in interface com.hazelcast.nio.serialization.SerializerHook
- 
Creates a new serializer for the serialization type 
- createService(Class<T>) - Method in class com.hazelcast.instance.DefaultNodeExtension
-  
- createService(Class<T>) - Method in interface com.hazelcast.instance.NodeExtension
- 
Creates a service which is an implementation of given type parameter. 
- createServiceProxyFactory(Class<T>) - Method in interface com.hazelcast.client.ClientExtension
- 
Creates a ClientProxyFactoryfor the supplied service class.
 
- createServiceProxyFactory(Class<T>) - Method in class com.hazelcast.client.impl.DefaultClientExtension
-  
- createSetOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createSetOperation(String, Data, Data, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createSetOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createSetOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-  
- createSetWithPopulatedPartitionIds(int) - Method in class com.hazelcast.map.impl.query.MapQueryEngineImpl
-  
- createSimpleEntryView(K, V, Record) - Static method in class com.hazelcast.map.impl.EntryViews
-  
- createSimpleEntryView() - Static method in class com.hazelcast.map.impl.EntryViews
-  
- createSingleOrBatchInvalidationOperation(String, Data, List<Data>) - Static method in class com.hazelcast.map.impl.nearcache.AbstractNearCacheInvalidator
-  
- createSizeOperationFactory() - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-  
- createSizeOperationFactory() - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-  
- createSocketChannelWrapperFactory() - Method in interface com.hazelcast.client.ClientExtension
- 
- createSocketChannelWrapperFactory() - Method in class com.hazelcast.client.impl.DefaultClientExtension
-  
- createSocketConnection(Address) - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-  
- createSocketInterceptor() - Method in interface com.hazelcast.client.ClientExtension
- 
Creates a  SocketInterceptor to be used by this client if available,
 otherwise returns  null
- createSocketInterceptor() - Method in class com.hazelcast.client.impl.DefaultClientExtension
-  
- createSplitBrainJoinMessage() - Method in class com.hazelcast.instance.Node
-  
- createStats(String) - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- createStorage(RecordFactory<R>, InMemoryFormat) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- createStoreEvent(E) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.StoreEvent
-  
- createThread(Runnable) - Method in class com.hazelcast.util.executor.AbstractExecutorThreadFactory
-  
- createThread(Runnable) - Method in class com.hazelcast.util.executor.PoolExecutorThreadFactory
-  
- createThread(Runnable) - Method in class com.hazelcast.util.executor.SingleExecutorThreadFactory
-  
- createTimedMemberState() - Method in class com.hazelcast.internal.management.TimedMemberStateFactory
-  
- createTransactionalObject(String, Transaction) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- createTransactionalObject(String, Transaction) - Method in class com.hazelcast.collection.impl.list.ListService
-  
- createTransactionalObject(String, Transaction) - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- createTransactionalObject(String, Transaction) - Method in class com.hazelcast.collection.impl.set.SetService
-  
- createTransactionalObject(String, Transaction) - Method in class com.hazelcast.map.impl.MapService
-  
- createTransactionalObject(String, Transaction) - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- createTransactionalObject(String, Transaction) - Method in interface com.hazelcast.spi.TransactionalService
-  
- CreateTransactionRequest - Class in com.hazelcast.transaction.client
-  
- CreateTransactionRequest() - Constructor for class com.hazelcast.transaction.client.CreateTransactionRequest
-  
- CreateTransactionRequest(TransactionOptions) - Constructor for class com.hazelcast.transaction.client.CreateTransactionRequest
-  
- createTryPutOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createTryPutOperation(String, Data, Data, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createTryPutOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createTryPutOperation(String, Data, Data, long) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-  
- createTryRemoveOperation(String, Data, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createTryRemoveOperation(String, Data, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createTryRemoveOperation(String, Data, long) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createTryRemoveOperation(String, Data, long) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-  
- CreateTxBackupLogOperation - Class in com.hazelcast.transaction.impl.operations
-  
- CreateTxBackupLogOperation() - Constructor for class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
-  
- CreateTxBackupLogOperation(String, String) - Constructor for class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
-  
- createTxnDeleteOperation(String, Data, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createTxnDeleteOperation(String, Data, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createTxnDeleteOperation(String, Data, long) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createTxnDeleteOperation(String, Data, long) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-  
- createTxnLockAndGetOperation(String, Data, long, long, String, boolean) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createTxnLockAndGetOperation(String, Data, long, long, String, boolean) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createTxnLockAndGetOperation(String, Data, long, long, String, boolean) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createTxnSetOperation(String, Data, Data, long, long) - Method in class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- createTxnSetOperation(String, Data, Data, long, long) - Method in interface com.hazelcast.map.impl.operation.MapOperationProvider
-  
- createTxnSetOperation(String, Data, Data, long, long) - Method in class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- createTxnSetOperation(String, Data, Data, long, long) - Method in class com.hazelcast.map.impl.operation.WANAwareOperationProvider
-  
- createWithoutValue(K) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntries
-  
- createWithoutValue(K, long, int) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntries
-  
- createWriteBehindManager(MapStoreContext) - Static method in class com.hazelcast.map.impl.mapstore.MapStoreManagers
-  
- createWriteBehindProcessor(MapStoreContext) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessors
-  
- createWriteBehindStore(MapStoreContext, int, WriteBehindProcessor) - Static method in class com.hazelcast.map.impl.mapstore.MapDataStores
- 
Creates a write behind data store. 
- createWriteHandler(TcpIpConnection, IOService) - Method in class com.hazelcast.instance.DefaultNodeExtension
-  
- createWriteHandler(TcpIpConnection, IOService) - Method in interface com.hazelcast.instance.NodeExtension
- 
Creates a WriteHandler for given Connection instance. 
- createWriteHandler(TcpIpConnection) - Method in interface com.hazelcast.nio.IOService
-  
- createWriteHandler(TcpIpConnection) - Method in class com.hazelcast.nio.NodeIOService
-  
- createWriteThroughManager(MapStoreContext) - Static method in class com.hazelcast.map.impl.mapstore.MapStoreManagers
-  
- createWriteThroughStore(MapStoreContext) - Static method in class com.hazelcast.map.impl.mapstore.MapDataStores
- 
Creates a write through data store. 
- CreateXATransactionRequest - Class in com.hazelcast.transaction.client
-  
- CreateXATransactionRequest() - Constructor for class com.hazelcast.transaction.client.CreateXATransactionRequest
-  
- CreateXATransactionRequest(SerializableXID, int) - Constructor for class com.hazelcast.transaction.client.CreateXATransactionRequest
-  
- creationTime - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
- 
This field is not mutated (read only) so no need to define it as volatile. 
- creationTime - Variable in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-  
- creationTime - Variable in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-  
- creationTime - Variable in class com.hazelcast.collection.impl.collection.CollectionItem
-  
- creationTime - Variable in class com.hazelcast.collection.impl.queue.QueueItem
-  
- creationTime - Variable in class com.hazelcast.map.impl.record.AbstractRecord
-  
- creationTime - Variable in class com.hazelcast.map.impl.record.RecordInfo
-  
- CREDENTIAL - Static variable in class com.hazelcast.jclouds.JCloudsProperties
- 
Unique credential specific to users cloud accounts identity 
- CREDENTIAL_PATH - Static variable in class com.hazelcast.jclouds.JCloudsProperties
- 
Property used to define JSON credentials file specific to Google Compute Engine 
- credentials - Variable in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
-  
- Credentials - Interface in com.hazelcast.security
- 
Credentials is a container object for endpoint (Members and Clients)
 security attributes. 
- CredentialsFactoryConfig - Class in com.hazelcast.config
- 
Contains the configuration for Credentials Factory. 
- CredentialsFactoryConfig() - Constructor for class com.hazelcast.config.CredentialsFactoryConfig
-  
- CredentialsFactoryConfig(String) - Constructor for class com.hazelcast.config.CredentialsFactoryConfig
-  
- CSHARP - Static variable in class com.hazelcast.client.ClientTypes
- 
CSHARP client protocol id 
- currentIndex - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-  
- currentTask - Variable in class com.hazelcast.spi.impl.operationexecutor.OperationRunner
-  
- currentTask() - Method in class com.hazelcast.spi.impl.operationexecutor.OperationRunner
- 
Returns the current task that is executing. 
- currentThread() - Method in class com.hazelcast.spi.impl.operationexecutor.OperationRunner
- 
Get the thread that is currently running this OperationRunner instance. 
- currentTimeMillis() - Method in class com.hazelcast.util.Clock.ClockImpl
-  
- currentTimeMillis() - Static method in class com.hazelcast.util.Clock
-  
- cursor() - Method in class com.hazelcast.util.collection.Long2LongHashMap
- 
Provides a cursor over the map's entries. 
- data - Variable in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
-  
- DATA - Static variable in class com.hazelcast.client.impl.protocol.ResponseMessageConst
-  
- data - Variable in class com.hazelcast.collection.impl.queue.QueueItem
-  
- Data - Interface in com.hazelcast.nio.serialization
- 
Data is basic unit of serialization. 
- data - Variable in class com.hazelcast.topic.impl.TopicEvent
-  
- DATA_MEMBER_SELECTOR - Static variable in class com.hazelcast.cluster.memberselector.MemberSelectors
- 
A  MemberSelector instance that selects only data members that own a partition 
- DATA_OFFSET - Static variable in class com.hazelcast.internal.serialization.impl.HeapData
-  
- DataAwareEntryEvent - Class in com.hazelcast.map.impl
-  
- DataAwareEntryEvent(Member, int, String, Data, Data, Data, Data, SerializationService) - Constructor for class com.hazelcast.map.impl.DataAwareEntryEvent
-  
- DataAwareItemEvent - Class in com.hazelcast.collection.common
- 
- DataAwareItemEvent(String, ItemEventType, Data, Member, SerializationService) - Constructor for class com.hazelcast.collection.common.DataAwareItemEvent
-  
- DataAwareMessage - Class in com.hazelcast.topic.impl
-  
- DataAwareMessage(String, Data, long, Member, SerializationService) - Constructor for class com.hazelcast.topic.impl.DataAwareMessage
-  
- dataKey - Variable in class com.hazelcast.map.impl.event.EntryEventData
-  
- dataKey - Variable in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-  
- dataKey - Variable in class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-  
- dataMemberCount - Variable in class com.hazelcast.cluster.impl.JoinMessage
-  
- dataMergingValue - Variable in class com.hazelcast.map.impl.event.EntryEventData
-  
- dataNewValue - Variable in class com.hazelcast.map.impl.event.EntryEventData
-  
- dataOldValue - Variable in class com.hazelcast.map.impl.event.EntryEventData
-  
- dataOldValue - Variable in class com.hazelcast.map.impl.operation.BasePutOperation
-  
- dataOldValue - Variable in class com.hazelcast.map.impl.operation.BaseRemoveOperation
-  
- DataRecordFactory - Class in com.hazelcast.map.impl.record
-  
- DataRecordFactory(MapConfig, SerializationService, PartitioningStrategy) - Constructor for class com.hazelcast.map.impl.record.DataRecordFactory
-  
- DataReplicatedRecordStore - Class in com.hazelcast.replicatedmap.impl.record
- 
- DataReplicatedRecordStore(String, ReplicatedMapService, int) - Constructor for class com.hazelcast.replicatedmap.impl.record.DataReplicatedRecordStore
-  
- DataSerializable - Interface in com.hazelcast.nio.serialization
- 
DataSerializable is a serialization method as an alternative to standard Java serialization. 
- dataSerializableFactories - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- DataSerializableFactory - Interface in com.hazelcast.nio.serialization
- 
DataSerializableFactory is used to create IdentifiedDataSerializable instances during de-serialization. 
- dataSerializerAdapter - Variable in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- DataSerializerHook - Interface in com.hazelcast.internal.serialization
-  
- dataSize() - Method in class com.hazelcast.internal.serialization.impl.HeapData
-  
- dataSize() - Method in interface com.hazelcast.nio.serialization.Data
- 
Returns size of internal binary data in bytes 
- dataToValue(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- dataToValue(Data) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-  
- dataToValue(Data) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- dataValue - Variable in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-  
- DATE_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
-  
- DATE_FORMAT - Static variable in class com.hazelcast.aws.impl.Constants
-  
- deactivate() - Method in interface com.hazelcast.osgi.impl.HazelcastInternalOSGiService
- 
Deactivates the service. 
- DEAD_MEMBER_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-  
- DeadMemberBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
-  
- DeadMemberBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.DeadMemberBackupOperation
-  
- DeadMemberBackupOperation(String, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.DeadMemberBackupOperation
-  
- decode(byte[]) - Static method in class com.hazelcast.util.Base64
- 
Decodes Base64 data into octects 
- decodeAddResponse(ClientMessage) - Method in interface com.hazelcast.client.spi.impl.ListenerMessageCodec
-  
- decodeClientMessage(ClientMessage) - Method in interface com.hazelcast.client.impl.ClientMessageDecoder
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAddAndGetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterAndGetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongApplyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongCompareAndSetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongDecrementAndGetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAddMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAlterMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndIncrementMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndSetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongIncrementAndGetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongSetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterAndGetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceApplyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceClearMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceCompareAndSetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceContainsMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndAlterMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndSetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceIsNullMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetAndGetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationCustomCredentialsMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddEntryListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddInvalidationListenerTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheContainsKeyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheCreateConfigMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEntryProcessorMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndRemoveMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndReplaceMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetConfigMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutIfAbsentMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheReplaceMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheSizeMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionAwaitMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionBeforeAwaitMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchAwaitMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchCountDownMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchGetCountMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchTrySetCountMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnAddressMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnPartitionMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllWithIndexMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddWithIndexMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListClearMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRemoveAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRetainAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListIndexOfMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListIsEmptyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListIteratorMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListLastIndexOfMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListListIteratorMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveWithIndexMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListSetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListSizeMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.list.ListSubMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockForceUnlockMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockGetLockCountMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockGetRemainingLeaseTimeMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockIsLockedByCurrentThreadMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockIsLockedMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockLockMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockTryLockMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.lock.LockUnlockMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyWithPredicateMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerWithPredicateMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddIndexMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddInterceptorMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddNearCacheEntryListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearNearCacheMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsKeyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsValueMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapDeleteMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPagingPredicateMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPredicateMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntrySetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnAllKeysMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeysMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteWithPredicateMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetEntryViewMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPagingPredicateMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutTransientMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveEntryListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveIfSameMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveInterceptorMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemovePartitionLostListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapReplaceIfSameMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapReplaceMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSizeMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSubmitToKeyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryLockMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryPutMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryRemoveMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapUnlockMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPagingPredicateMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPredicateMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceCancelMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForCustomMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForListMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMapMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMultiMapMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForSetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceJobProcessInformationMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerToKeyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapClearMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsEntryMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsKeyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsValueMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapGetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapPutMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValueCountMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.NoSuchMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueClearMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRemoveAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRetainAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMaxSizeMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIsEmptyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIteratorMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueOfferMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePeekMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePollMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePutMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemainingCapacityMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueSizeMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueTakeMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerWithPredicateMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddNearCacheListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsKeyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsValueMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapEntrySetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapIsEmptyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapKeySetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapSizeMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapValuesMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferCapacityMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferHeadSequenceMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadManyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadOneMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferRemainingCapacityMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferSizeMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferTailSequenceMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreAcquireMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreAvailablePermitsMessageTasks
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreDrainPermitsMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreInitMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreReducePermitsMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreReleaseMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreTryAcquireMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetClearMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRemoveAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRetainAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetGetAllMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetIsEmptyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.set.SetSizeMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicAddMessageListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicPublishMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicRemoveMessageListenerMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCommitMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCreateMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionRollbackMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAClearRemoteTransactionMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XACollectTransactionsMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAFinalizeTransactionMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCommitMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCreateMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionPrepareMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionRollbackMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListAddMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListRemoveMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListSizeMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapContainsKeyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapDeleteMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetForUpdateMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapIsEmptyMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetWithPredicateMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutIfAbsentMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveIfSameMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceIfSameMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSizeMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesWithPredicateMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapGetMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapPutMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveEntryMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapSizeMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapValueCountMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueOfferMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePeekMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePollMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueSizeMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueTakeMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetAddMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetRemoveMessageTask
-  
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetSizeMessageTask
-  
- decodeRemoveResponse(ClientMessage) - Method in interface com.hazelcast.client.spi.impl.ListenerMessageCodec
-  
- decompress(byte[]) - Static method in class com.hazelcast.nio.IOUtil
-  
- decreaseCacheEntryListenerCount() - Method in class com.hazelcast.cache.impl.CacheContext
-  
- decreaseEntryCount() - Method in class com.hazelcast.cache.impl.CacheContext
-  
- decreaseEntryCount(long) - Method in class com.hazelcast.cache.impl.CacheContext
-  
- decreaseEntryCount() - Method in class com.hazelcast.cache.impl.CacheEntryCountResolver
-  
- decreaseEntryCount(long) - Method in class com.hazelcast.cache.impl.CacheEntryCountResolver
-  
- decreaseInvalidationListenerCount() - Method in class com.hazelcast.cache.impl.CacheContext
-  
- decreaseInvalidationListenerCount() - Method in class com.hazelcast.map.impl.MapContainer
-  
- decrementAndGet() - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-  
- decrementAndGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- decrementAndGet() - Method in interface com.hazelcast.core.IAtomicLong
- 
Atomically decrements the current value by one. 
- decrementAndGet() - Method in class com.hazelcast.jmx.AtomicLongMBean
-  
- decrementOwnedEntryCount() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-  
- decrementOwnedEntryMemoryCost(long) - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-  
- decrementPendingPacketCount() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- DEFAULT_ASNYC_FILLUP - Static variable in class com.hazelcast.config.ReplicatedMapConfig
- 
Default value of asynchronous fill up 
- DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.CollectionConfig
- 
The default number of asynchronous backups 
- DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.MultiMapConfig
- 
The default number of asynchronous backups for this MultiMap. 
- DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.QueueConfig
- 
Default value of the asynchronous backup count. 
- DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.RingbufferConfig
- 
Default value of asynchronous backup count 
- DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.SemaphoreConfig
- 
Default asynchronous backup count 
- DEFAULT_BACKUP_COUNT - Static variable in class com.hazelcast.config.CacheSimpleConfig
- 
The default number of backups. 
- DEFAULT_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
- 
The number of default backup counter 
- DEFAULT_BATCH_SIZE - Static variable in class com.hazelcast.config.QueryCacheConfig
- 
By default, after reaching this minimum size, node immediately sends buffered events to QueryCache.
 
- DEFAULT_BUFFER_SIZE - Static variable in class com.hazelcast.config.QueryCacheConfig
- 
By default, only buffer last 16 events fired from a partition. 
- DEFAULT_BUFFER_SIZE_BYTE - Static variable in class com.hazelcast.client.config.SocketOptions
- 
default buffer size of Bytes 
- DEFAULT_CACHE_MERGE_POLICY - Static variable in class com.hazelcast.config.CacheSimpleConfig
- 
Default policy for merging 
- DEFAULT_CACHED_DESERIALIZED_VALUES - Static variable in class com.hazelcast.config.MapConfig
- 
We want to cache values only when an index is defined. 
- DEFAULT_CALL_TIMEOUT - Static variable in class com.hazelcast.spi.InvocationBuilder
- 
Default call timeout. 
- DEFAULT_CAPACITY - Static variable in class com.hazelcast.config.RingbufferConfig
- 
Default value of capacity of the RingBuffer. 
- DEFAULT_CHUNK_SIZE - Static variable in class com.hazelcast.config.JobTrackerConfig
- 
Default value of chunk size. 
- DEFAULT_COALESCE - Static variable in class com.hazelcast.config.QueryCacheConfig
- 
Default value of coalesce property. 
- DEFAULT_COMMUNICATE_STATS - Static variable in class com.hazelcast.config.JobTrackerConfig
- 
Default boolean value of communication statics.define how a map reduce job behaves 
- DEFAULT_CONCURRENCY_LEVEL - Static variable in class com.hazelcast.config.ReplicatedMapConfig
- 
Default value of concurrency level 
- DEFAULT_DATA_LOAD_TIMEOUT - Static variable in class com.hazelcast.config.HotRestartPersistenceConfig
- 
Default load timeout 
- DEFAULT_DELAY_SECONDS - Static variable in class com.hazelcast.config.QueryCacheConfig
- 
Default value of delay seconds which an event wait in the buffer of a node, before sending to QueryCache.
 
- DEFAULT_DESERIALIZE_RESULT - Static variable in class com.hazelcast.spi.InvocationBuilder
- 
True that the result of an operation automatically should be deserialized to an object. 
- DEFAULT_EMPTY_QUEUE_TTL - Static variable in class com.hazelcast.config.QueueConfig
- 
Default value for the TTL (time to live) for empty Queue. 
- DEFAULT_ENABLED - Static variable in class com.hazelcast.config.MulticastConfig
- 
Whether the multicast discovery mechanism has been enabled 
- DEFAULT_EVICTION_PERCENTAGE - Static variable in class com.hazelcast.config.MapConfig
- 
The number of default eviction percentage 
- DEFAULT_EVICTION_POLICY - Static variable in class com.hazelcast.config.CacheSimpleConfig
- 
Default Eviction Policy. 
- DEFAULT_EVICTION_POLICY - Static variable in class com.hazelcast.config.EvictionConfig
- 
Default Eviction Policy. 
- DEFAULT_EVICTION_POLICY - Static variable in class com.hazelcast.config.MapConfig
- 
Default policy for eviction 
- DEFAULT_EVICTION_POLICY - Static variable in class com.hazelcast.config.NearCacheConfig
- 
Default eviction policy 
- DEFAULT_EVICTION_STRATEGY - Static variable in enum com.hazelcast.internal.eviction.EvictionStrategyType
- 
- DEFAULT_EXPIRATION_TASK_DELAY_IN_SECONDS - Static variable in interface com.hazelcast.cache.impl.nearcache.NearCache
- 
Default expiration task delay time as seconds 
- DEFAULT_EXPIRATION_TASK_INITIAL_DELAY_IN_SECONDS - Static variable in interface com.hazelcast.cache.impl.nearcache.NearCache
- 
Default expiration task initial delay time as seconds 
- DEFAULT_GLOBAL_ORDERING_ENABLED - Static variable in class com.hazelcast.config.TopicConfig
- 
Default global ordering configuration. 
- DEFAULT_GRACEFUL_SHUTDOWN_WAIT - Static variable in class com.hazelcast.instance.LifecycleServiceImpl
-  
- DEFAULT_GROUP_NAME - Static variable in class com.hazelcast.config.GroupConfig
- 
Default group name 
- DEFAULT_GROUP_NAME - Static variable in interface com.hazelcast.osgi.impl.HazelcastInternalOSGiService
- 
- DEFAULT_GROUP_PASSWORD - Static variable in class com.hazelcast.config.GroupConfig
- 
Default group password 
- DEFAULT_ID - Static variable in interface com.hazelcast.osgi.impl.HazelcastInternalOSGiService
- 
- DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.CacheSimpleConfig
- 
Default InMemory Format. 
- DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.MapConfig
- 
Default In-Memory format is binary 
- DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.QueryCacheConfig
- 
By default, hold values of entries in QueryCacheas binary.
 
- DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.ReplicatedMapConfig
- 
Default value of In-memory format 
- DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.RingbufferConfig
- 
Default value for the InMemoryFormat. 
- DEFAULT_INCLUDE_VALUE - Static variable in class com.hazelcast.config.QueryCacheConfig
- 
By default, also cache values of entries besides keys. 
- DEFAULT_INITIAL_CAPACITY - Static variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- DEFAULT_INITIAL_CAPACITY - Static variable in class com.hazelcast.cache.impl.nearcache.impl.store.BaseHeapNearCacheRecordStore
-  
- DEFAULT_LOAD_FACTOR - Static variable in class com.hazelcast.util.collection.Long2LongHashMap
- 
The default load factor for constructors not explicitly supplying it 
- DEFAULT_LOAD_FACTOR - Static variable in class com.hazelcast.util.collection.Long2ObjectHashMap
- 
The default load factor for constructors not explicitly supplying it 
- DEFAULT_LOOPBACK_MODE_ENABLED - Static variable in class com.hazelcast.config.MulticastConfig
- 
Default flag that indicates if the loopback mode
 is turned on or off. 
- DEFAULT_MAP_MERGE_POLICY - Static variable in class com.hazelcast.config.MapConfig
- 
Default policy for merging 
- DEFAULT_MAP_NAME - Static variable in class com.hazelcast.internal.ascii.memcache.MemcacheCommandProcessor
-  
- DEFAULT_MAX_ENTRY_COUNT - Static variable in class com.hazelcast.config.EvictionConfig
- 
Default maximum entry count. 
- DEFAULT_MAX_IDLE_SECONDS - Static variable in class com.hazelcast.config.MapConfig
- 
The number of default time to wait eviction in seconds 
- DEFAULT_MAX_IDLE_SECONDS - Static variable in class com.hazelcast.config.NearCacheConfig
- 
Default value of idle in seconds for eviction. 
- DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.CollectionConfig
- 
Default maximum size for the Configuration. 
- DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.MaxSizeConfig
- 
Default maximum size of map. 
- DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.NearCacheConfig
- 
Default value of maximum size 
- DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.QueueConfig
- 
Default value for the maximum size of the Queue. 
- DEFAULT_MAX_THREAD_SIZE - Static variable in class com.hazelcast.config.JobTrackerConfig
- 
Default size of thread. 
- DEFAULT_MEMORY_FORMAT - Static variable in class com.hazelcast.config.NearCacheConfig
- 
Default memory format 
- DEFAULT_MERGE_POLICY - Static variable in class com.hazelcast.config.ReplicatedMapConfig
- 
Default policy for merging 
- DEFAULT_METADATA_SPACE_PERCENTAGE - Static variable in class com.hazelcast.config.NativeMemoryConfig
- 
Default metadata space percentage 
- DEFAULT_MIN_BLOCK_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
- 
Default minimum block size 
- DEFAULT_MIN_EVICTION_CHECK_MILLIS - Static variable in class com.hazelcast.config.MapConfig
- 
Minimum time in milliseconds which should pass before asking
 if a partition of this map is evictable or not. 
- DEFAULT_MULTICAST_GROUP - Static variable in class com.hazelcast.config.MulticastConfig
- 
Default group of multicast. 
- DEFAULT_MULTICAST_PORT - Static variable in class com.hazelcast.config.MulticastConfig
- 
Default value of port. 
- DEFAULT_MULTICAST_TIMEOUT_SECONDS - Static variable in class com.hazelcast.config.MulticastConfig
- 
Default timeout of multicast in seconds. 
- DEFAULT_MULTICAST_TTL - Static variable in class com.hazelcast.config.MulticastConfig
- 
Default value of time to live of multicast. 
- DEFAULT_PAGE_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
- 
Default page size 
- DEFAULT_PARTITION_COUNT - Static variable in class com.hazelcast.monitor.impl.MemberPartitionStateImpl
-  
- DEFAULT_POOL_SIZE - Static variable in class com.hazelcast.config.ExecutorConfig
- 
The number of executor threads per Member for the Executor based on this configuration. 
- DEFAULT_POPULATE - Static variable in class com.hazelcast.config.QueryCacheConfig
- 
By default, execute an initial population query prior to creation of the QueryCache.
 
- DEFAULT_PORT - Static variable in class com.hazelcast.config.NetworkConfig
- 
Default value of port number 
- DEFAULT_POWER - Static variable in class com.hazelcast.config.NativeMemoryConfig
- 
Default power for page size 
- DEFAULT_QUEUE_CAPACITY - Static variable in class com.hazelcast.config.ExecutorConfig
- 
Capacity of Queue 
- DEFAULT_QUEUE_SIZE - Static variable in class com.hazelcast.config.JobTrackerConfig
- 
Default value of Queue size. 
- DEFAULT_READ_BATCH_SIZE - Static variable in class com.hazelcast.client.config.ClientReliableTopicConfig
- 
The default read batch size. 
- DEFAULT_READ_BATCH_SIZE - Static variable in class com.hazelcast.config.ReliableTopicConfig
- 
The default read batch size. 
- DEFAULT_REPLICA_INDEX - Static variable in class com.hazelcast.spi.InvocationBuilder
- 
Default replica index. 
- DEFAULT_REPLICA_SYNC_DELAY - Static variable in interface com.hazelcast.partition.InternalPartitionService
-  
- DEFAULT_REPLICATION_DELAY_MILLIS - Static variable in class com.hazelcast.config.ReplicatedMapConfig
- 
Default value of delay of replication in millisecond 
- DEFAULT_RETRY_COUNT - Static variable in class com.hazelcast.config.JobTrackerConfig
- 
Default value of retry counter. 
- DEFAULT_STATISTICS_ENABLED - Static variable in class com.hazelcast.config.ReliableTopicConfig
- 
Default value for statistics enabled. 
- DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.CollectionConfig
- 
The default number of synchronous backups 
- DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.MultiMapConfig
- 
The default number of synchronous backups for this MultiMap. 
- DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.QueueConfig
- 
Default value for the sychronous backup count. 
- DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.RingbufferConfig
- 
Default value of synchronous backup count 
- DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.SemaphoreConfig
- 
Default synchronous backup count 
- DEFAULT_TIMEOUT_MILLIS - Static variable in class com.hazelcast.transaction.TransactionOptions
- 
2 minutes as default timeout value 
- DEFAULT_TOPIC_OVERLOAD_POLICY - Static variable in class com.hazelcast.client.config.ClientReliableTopicConfig
- 
The default slow consumer policy. 
- DEFAULT_TOPIC_OVERLOAD_POLICY - Static variable in class com.hazelcast.config.ReliableTopicConfig
- 
The default slow consumer policy. 
- DEFAULT_TOPOLOGY_CHANGED_STRATEGY - Static variable in class com.hazelcast.config.JobTrackerConfig
- 
Define how a map reduce job behaves. 
- DEFAULT_TRY_COUNT - Static variable in class com.hazelcast.spi.InvocationBuilder
- 
Default try count. 
- DEFAULT_TRY_PAUSE_MILLIS - Static variable in class com.hazelcast.spi.InvocationBuilder
- 
Default try pause in milliseconds. 
- DEFAULT_TTL - Static variable in interface com.hazelcast.map.impl.recordstore.RecordStore
- 
Default TTL value of a record. 
- DEFAULT_TTL_SECONDS - Static variable in class com.hazelcast.config.MapConfig
- 
The number of default Time to Live in seconds 
- DEFAULT_TTL_SECONDS - Static variable in class com.hazelcast.config.NearCacheConfig
- 
Default value of time to live in seconds. 
- DEFAULT_TTL_SECONDS - Static variable in class com.hazelcast.config.RingbufferConfig
- 
Default value for the time to live property. 
- DEFAULT_VALIDATION_TIMEOUT - Static variable in class com.hazelcast.config.HotRestartPersistenceConfig
- 
Default validation timeout 
- DEFAULT_VALUE_COLLECTION_TYPE - Static variable in class com.hazelcast.config.MultiMapConfig
- 
Default value collection type of this MultiMap. 
- DEFAULT_WRITE_BATCH_SIZE - Static variable in class com.hazelcast.config.MapStoreConfig
- 
Default batch size for writing 
- DEFAULT_WRITE_COALESCING - Static variable in class com.hazelcast.config.MapStoreConfig
- 
Default write coalescing behavior 
- DEFAULT_WRITE_DELAY_SECONDS - Static variable in class com.hazelcast.config.MapStoreConfig
- 
Default delay seconds for writing 
- DefaultAddressProvider - Class in com.hazelcast.client.spi.impl
- 
Default address provider of hazelcast
 Loads addresses from hazelcast configuration 
- DefaultAddressProvider(ClientNetworkConfig) - Constructor for class com.hazelcast.client.spi.impl.DefaultAddressProvider
-  
- DefaultAddressTranslator - Class in com.hazelcast.client.spi.impl
- 
Default Address Translator is a no-op. 
- DefaultAddressTranslator() - Constructor for class com.hazelcast.client.spi.impl.DefaultAddressTranslator
-  
- DefaultArgumentParser - Class in com.hazelcast.query.impl
- 
ArgumentParser that's used by default. 
- DefaultArgumentParser() - Constructor for class com.hazelcast.query.impl.DefaultArgumentParser
-  
- DefaultCacheEntryView - Class in com.hazelcast.cache.impl.merge.entry
- 
- DefaultCacheEntryView() - Constructor for class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
-  
- DefaultCacheEntryView(Data, Data, long, long, long) - Constructor for class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
-  
- defaultClassLoader - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-  
- DefaultClientConnectionManagerFactory - Class in com.hazelcast.client.impl
-  
- DefaultClientConnectionManagerFactory() - Constructor for class com.hazelcast.client.impl.DefaultClientConnectionManagerFactory
-  
- DefaultClientExtension - Class in com.hazelcast.client.impl
-  
- DefaultClientExtension() - Constructor for class com.hazelcast.client.impl.DefaultClientExtension
-  
- DefaultContext<KeyIn,ValueIn> - Class in com.hazelcast.mapreduce.impl.task
- 
This is the internal default implementation of a map reduce context mappers emit values to. 
- DefaultContext(CombinerFactory<KeyIn, ValueIn, ?>, MapCombineTask) - Constructor for class com.hazelcast.mapreduce.impl.task.DefaultContext
-  
- DefaultDiscoveryService - Class in com.hazelcast.spi.discovery.impl
-  
- DefaultDiscoveryService(DiscoveryServiceSettings) - Constructor for class com.hazelcast.spi.discovery.impl.DefaultDiscoveryService
-  
- DefaultDiscoveryServiceProvider - Class in com.hazelcast.spi.discovery.impl
-  
- DefaultDiscoveryServiceProvider() - Constructor for class com.hazelcast.spi.discovery.impl.DefaultDiscoveryServiceProvider
-  
- defaultExpiryPolicy - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- DefaultGarbageCollectorStats - Class in com.hazelcast.memory
- 
Default implementation of GarbageCollectorStats. 
- DefaultGarbageCollectorStats() - Constructor for class com.hazelcast.memory.DefaultGarbageCollectorStats
-  
- DefaultMapOperationProvider - Class in com.hazelcast.map.impl.operation
- 
Creates map operations. 
- DefaultMapOperationProvider() - Constructor for class com.hazelcast.map.impl.operation.DefaultMapOperationProvider
-  
- DefaultMemberGroup - Class in com.hazelcast.partition.membergroup
-  
- DefaultMemberGroup() - Constructor for class com.hazelcast.partition.membergroup.DefaultMemberGroup
-  
- DefaultMemberGroup(Collection<Member>) - Constructor for class com.hazelcast.partition.membergroup.DefaultMemberGroup
-  
- DefaultMemoryStats - Class in com.hazelcast.memory
- 
Default implementation of MemoryStats. 
- DefaultMemoryStats() - Constructor for class com.hazelcast.memory.DefaultMemoryStats
-  
- DefaultNearCache<K,V> - Class in com.hazelcast.cache.impl.nearcache.impl
-  
- DefaultNearCache(String, NearCacheConfig, NearCacheContext) - Constructor for class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache
-  
- DefaultNearCache(String, NearCacheConfig, NearCacheContext, NearCacheRecordStore<K, V>) - Constructor for class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache
-  
- DefaultNearCache.ExpirationTask - Class in com.hazelcast.cache.impl.nearcache.impl
-  
- DefaultNearCache.ExpirationTask() - Constructor for class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache.ExpirationTask
-  
- DefaultNearCacheManager - Class in com.hazelcast.cache.impl.nearcache.impl
-  
- DefaultNearCacheManager() - Constructor for class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCacheManager
-  
- DefaultNodeContext - Class in com.hazelcast.instance
-  
- DefaultNodeContext() - Constructor for class com.hazelcast.instance.DefaultNodeContext
-  
- DefaultNodeExtension - Class in com.hazelcast.instance
-  
- DefaultNodeExtension(Node) - Constructor for class com.hazelcast.instance.DefaultNodeExtension
-  
- DefaultObjectNamespace - Class in com.hazelcast.spi
- 
- DefaultObjectNamespace() - Constructor for class com.hazelcast.spi.DefaultObjectNamespace
-  
- DefaultObjectNamespace(String, String) - Constructor for class com.hazelcast.spi.DefaultObjectNamespace
-  
- DefaultOperationProvider - Class in com.hazelcast.cache.impl
- 
- DefaultOperationProvider(String) - Constructor for class com.hazelcast.cache.impl.DefaultOperationProvider
-  
- DefaultOutOfMemoryHandler - Class in com.hazelcast.instance
- 
Default OutOfMemoryHandler implementation that tries to release local resources (threads, connections, memory)
 immediately and disconnects members from the rest of the cluster. 
- DefaultOutOfMemoryHandler() - Constructor for class com.hazelcast.instance.DefaultOutOfMemoryHandler
-  
- DefaultOutOfMemoryHandler(double) - Constructor for class com.hazelcast.instance.DefaultOutOfMemoryHandler
-  
- DefaultOutOfMemoryHandler(double, MemoryInfoAccessor) - Constructor for class com.hazelcast.instance.DefaultOutOfMemoryHandler
-  
- DefaultPartitioningStrategy - Class in com.hazelcast.partition.strategy
- 
- DefaultPartitioningStrategy() - Constructor for class com.hazelcast.partition.strategy.DefaultPartitioningStrategy
-  
- DefaultPortableReader - Class in com.hazelcast.internal.serialization.impl
- 
Can't be accessed concurrently 
- DefaultPortableWriter - Class in com.hazelcast.internal.serialization.impl
-  
- DefaultPortableWriter(PortableSerializer, BufferObjectDataOutput, ClassDefinition) - Constructor for class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
-  
- defaultProvider - Variable in class com.hazelcast.map.impl.operation.MapOperationProviders
-  
- DefaultQueryCacheEventData - Class in com.hazelcast.map.impl.querycache.event
- 
- DefaultQueryCacheEventData() - Constructor for class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- DefaultRecordStore - Class in com.hazelcast.map.impl.recordstore
- 
Default implementation of record-store. 
- DefaultRecordStore(MapContainer, int, MapKeyLoader, ILogger) - Constructor for class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- DefaultScheduleQueue - Class in com.hazelcast.spi.impl.operationexecutor.classic
-  
- DefaultScheduleQueue() - Constructor for class com.hazelcast.spi.impl.operationexecutor.classic.DefaultScheduleQueue
-  
- DefaultScheduleQueue(BlockingQueue, ConcurrentLinkedQueue) - Constructor for class com.hazelcast.spi.impl.operationexecutor.classic.DefaultScheduleQueue
-  
- DefaultSerializationServiceBuilder - Class in com.hazelcast.internal.serialization.impl
-  
- DefaultSerializationServiceBuilder() - Constructor for class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- DefaultSocketChannelWrapper - Class in com.hazelcast.nio.tcp
-  
- DefaultSocketChannelWrapper(SocketChannel) - Constructor for class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-  
- DefaultSocketChannelWrapperFactory - Class in com.hazelcast.nio.tcp
-  
- DefaultSocketChannelWrapperFactory() - Constructor for class com.hazelcast.nio.tcp.DefaultSocketChannelWrapperFactory
-  
- defaultURI - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-  
- DefaultValueCollector - Class in com.hazelcast.query.impl
-  
- DefaultValueCollector() - Constructor for class com.hazelcast.query.impl.DefaultValueCollector
-  
- DelayedEntries - Class in com.hazelcast.map.impl.mapstore.writebehind.entry
- 
Mainly contains static factory methods to create various  DelayedEntry instances. 
- DelayedEntry<K,V> - Interface in com.hazelcast.map.impl.mapstore.writebehind.entry
- 
- DelegatingFuture<V> - Class in com.hazelcast.util.executor
-  
- DelegatingFuture(ICompletableFuture, SerializationService) - Constructor for class com.hazelcast.util.executor.DelegatingFuture
-  
- DelegatingFuture(ICompletableFuture, SerializationService, V) - Constructor for class com.hazelcast.util.executor.DelegatingFuture
-  
- delete(Object) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- delete(Object) - Method in class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-  
- delete(Object) - Method in class com.hazelcast.client.txn.proxy.ClientTxnMapProxy
-  
- delete(Long) - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
-  
- delete(Object) - Method in interface com.hazelcast.core.BaseMap
- 
Removes the mapping for a key from this map if it is present. 
- delete(Object) - Method in interface com.hazelcast.core.IMap
- 
Removes the mapping for a key from this map if it is present
 (optional operation). 
- delete(K) - Method in interface com.hazelcast.core.MapStore
- 
Deletes the entry with a given key from the store. 
- delete(K) - Method in class com.hazelcast.core.MapStoreAdapter
- 
Deletes the entry with a given key from the store. 
- delete(Long) - Method in interface com.hazelcast.core.QueueStore
- 
Deletes the entry with a given key from the store. 
- delete(Object) - Method in interface com.hazelcast.core.TransactionalMap
- 
- delete(String, String) - Method in interface com.hazelcast.internal.ascii.TextCommandService
-  
- delete(String, String) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- DELETE - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- delete(Object) - Method in class com.hazelcast.map.impl.MapStoreWrapper
-  
- delete(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- delete(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- delete(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- delete(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-  
- delete(Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-  
- delete() - Method in class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-  
- delete(File) - Static method in class com.hazelcast.nio.IOUtil
- 
Ensures that the file described by the supplied parameter does not exist
 after the method returns. 
- deleteAll(Collection<Long>) - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
-  
- deleteAll(Collection<K>) - Method in interface com.hazelcast.core.MapStore
- 
Deletes multiple entries from the store. 
- deleteAll(Collection<K>) - Method in class com.hazelcast.core.MapStoreAdapter
- 
Deletes multiple entries from the store. 
- deleteAll(Collection<Long>) - Method in interface com.hazelcast.core.QueueStore
- 
Deletes multiple entries from the store. 
- deleteAll(String) - Method in interface com.hazelcast.internal.ascii.TextCommandService
-  
- deleteAll(String) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- deleteAll(Collection) - Method in class com.hazelcast.map.impl.MapStoreWrapper
-  
- deleteAllCacheEntry(Set<Data>) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- deleteCache(String, boolean, String, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- deleteCache(String, boolean, String, boolean) - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- deleteCacheConfig(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- deleteCacheConfig(String) - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- deleteCacheEntry(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- deleteCacheStat(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- deleteCacheStat(String) - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- DeleteCommand - Class in com.hazelcast.internal.ascii.memcache
-  
- DeleteCommand(String, int, boolean) - Constructor for class com.hazelcast.internal.ascii.memcache.DeleteCommand
-  
- DeleteCommandParser - Class in com.hazelcast.internal.ascii.memcache
-  
- DeleteCommandParser() - Constructor for class com.hazelcast.internal.ascii.memcache.DeleteCommandParser
-  
- DeleteCommandProcessor - Class in com.hazelcast.internal.ascii.memcache
-  
- DeleteCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.memcache.DeleteCommandProcessor
-  
- DELETED - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
-  
- deleteInternal(Data) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- deleteInternal(Data) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- deleteInternal(Data) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- DeleteOperation - Class in com.hazelcast.map.impl.operation
-  
- DeleteOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.DeleteOperation
-  
- DeleteOperation() - Constructor for class com.hazelcast.map.impl.operation.DeleteOperation
-  
- deleteRecord(Data, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- deleteRecord(Data, int, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- deleteRecord(Data, int, String, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- deleteRecordStore(String, boolean) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-  
- deleteSession(String, boolean) - Method in class com.hazelcast.web.ClusteredSessionService
- 
Delete session. 
- DeleteSessionEntryProcessor - Class in com.hazelcast.web.entryprocessor
- 
Entry processor which removes SessionState values if
 invalidate is true. 
- DeleteSessionEntryProcessor(boolean) - Constructor for class com.hazelcast.web.entryprocessor.DeleteSessionEntryProcessor
-  
- DeleteSessionEntryProcessor() - Constructor for class com.hazelcast.web.entryprocessor.DeleteSessionEntryProcessor
-  
- delta - Variable in class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
-  
- DenyAllPermissionCollection - Class in com.hazelcast.security.permission
-  
- DenyAllPermissionCollection() - Constructor for class com.hazelcast.security.permission.DenyAllPermissionCollection
-  
- deregister(S) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
-  
- deregister(S) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
- 
Deregisters all probes for a given source object. 
- deregister(String) - Method in class com.hazelcast.map.impl.InterceptorRegistry
- 
- deregister(Invocation) - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
- 
Deregisters an invocation. 
- deregisterAllListener(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- deregisterAllListener(String) - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- deregisterAllListeners(String, String) - Method in interface com.hazelcast.spi.EventService
- 
Deregisters all listeners belonging to the given service and topic. 
- deregisterAllListeners(String, String) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-  
- deregisterCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- deregisterCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- deregisterClient(HazelcastInstance) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
-  
- deregisterListener(String, String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- deRegisterListener() - Method in class com.hazelcast.cache.impl.client.CacheRemoveEntryListenerRequest
-  
- deRegisterListener() - Method in class com.hazelcast.cache.impl.client.CacheRemoveInvalidationListenerRequest
-  
- deRegisterListener() - Method in class com.hazelcast.cache.impl.client.CacheRemovePartitionLostListenerRequest
-  
- deregisterListener(String, String) - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- deRegisterListener() - Method in class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
-  
- deRegisterListener() - Method in class com.hazelcast.client.impl.client.RemoveDistributedObjectListenerRequest
-  
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.AbstractRemoveListenerMessageTask
-  
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
-  
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
-  
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
-  
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveListenerMessageTask
-  
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveEntryListenerMessageTask
-  
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemovePartitionLostListenerMessageTask
-  
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
-  
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveListenerMessageTask
-  
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
-  
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
-  
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
-  
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveListenerMessageTask
-  
- deRegisterListener() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicRemoveMessageListenerMessageTask
-  
- deregisterListener(String) - Method in interface com.hazelcast.client.spi.ClientListenerService
-  
- deregisterListener(String) - Method in class com.hazelcast.client.spi.ClientProxy
-  
- deregisterListener(String) - Method in class com.hazelcast.client.spi.impl.listener.ClientNonSmartListenerService
-  
- deregisterListener(String) - Method in class com.hazelcast.client.spi.impl.listener.ClientSmartListenerService
-  
- deRegisterListener() - Method in class com.hazelcast.collection.impl.collection.client.CollectionRemoveListenerRequest
-  
- deRegisterListener() - Method in class com.hazelcast.collection.impl.queue.client.RemoveListenerRequest
-  
- deRegisterListener() - Method in class com.hazelcast.map.impl.client.MapRemoveEntryListenerRequest
-  
- deRegisterListener() - Method in class com.hazelcast.map.impl.client.MapRemovePartitionLostListenerRequest
-  
- deRegisterListener() - Method in class com.hazelcast.multimap.impl.client.RemoveEntryListenerRequest
-  
- deRegisterListener() - Method in class com.hazelcast.partition.client.RemovePartitionLostListenerRequest
-  
- deRegisterListener() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-  
- deregisterListener(String, String, Object) - Method in interface com.hazelcast.spi.EventService
- 
Deregisters a listener with the given registration id. 
- deregisterListener(String, String, Object) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-  
- deRegisterListener() - Method in class com.hazelcast.topic.impl.client.RemoveMessageListenerRequest
-  
- deregisterServer(HazelcastInstance) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
-  
- DeregistrationOperation - Class in com.hazelcast.spi.impl.eventservice.impl.operations
-  
- DeregistrationOperation() - Constructor for class com.hazelcast.spi.impl.eventservice.impl.operations.DeregistrationOperation
-  
- DeregistrationOperation(String, String) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.operations.DeregistrationOperation
-  
- DescribeInstances - Class in com.hazelcast.aws.impl
-  
- DescribeInstances(AwsConfig, String) - Constructor for class com.hazelcast.aws.impl.DescribeInstances
-  
- destroy() - Method in interface com.hazelcast.cache.HazelcastCacheManager
- 
Destroys cache manager. 
- destroy() - Method in interface com.hazelcast.cache.ICache
- 
Closes the cache. 
- destroy() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- destroy() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
- 
Destroy all managed caches. 
- destroy() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Destroy is equivalent to below operations in the given order:
 
     clear all.
     close resources.
     unregister all listeners.
  
- destroy() - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache
-  
- destroy() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- destroy() - Method in interface com.hazelcast.cache.impl.nearcache.NearCache
- 
Clears the record store and destroys it. 
- destroy() - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheRecordStore
- 
Clears the record store and destroys it. 
- destroy() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- destroy() - Method in class com.hazelcast.client.map.impl.nearcache.ClientHeapNearCache
-  
- destroy() - Method in class com.hazelcast.client.spi.ClientProxy
-  
- destroy() - Method in class com.hazelcast.client.spi.ProxyManager
-  
- destroy() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- destroy() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- destroy() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorImpl
-  
- destroy() - Method in interface com.hazelcast.core.DistributedObject
- 
Destroys this object cluster-wide. 
- destroy() - Method in interface com.hazelcast.core.MapLoaderLifecycleSupport
- 
Hazelcast will call this method before shutting down. 
- destroy() - Method in class com.hazelcast.instance.HazelcastThreadGroup
- 
Destroys all threads in this ThreadGroup. 
- destroy() - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- destroy() - Method in class com.hazelcast.internal.serialization.impl.ArrayListStreamSerializer
-  
- destroy() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.TheByteArraySerializer
-  
- destroy() - Method in class com.hazelcast.internal.serialization.impl.LinkedListStreamSerializer
-  
- destroy() - Method in interface com.hazelcast.internal.serialization.SerializationService
-  
- destroy() - Method in class com.hazelcast.jca.ManagedConnectionImpl
-  
- destroy() - Method in class com.hazelcast.jclouds.ComputeServiceBuilder
-  
- destroy() - Method in class com.hazelcast.jclouds.JCloudsDiscoveryStrategy
-  
- destroy() - Method in class com.hazelcast.jmx.ManagementService
-  
- destroy() - Method in class com.hazelcast.map.impl.MapStoreWrapper
-  
- destroy(String) - Method in class com.hazelcast.map.impl.nearcache.BatchInvalidator
-  
- destroy() - Method in class com.hazelcast.map.impl.nearcache.NearCacheImpl
-  
- destroy(String) - Method in interface com.hazelcast.map.impl.nearcache.NearCacheInvalidator
- 
Removes supplied maps invalidation queue and flushes its content. 
- destroy(String) - Method in class com.hazelcast.map.impl.nearcache.NonStopInvalidator
-  
- destroy() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- destroy() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- destroy() - Method in interface com.hazelcast.map.impl.recordstore.Storage
-  
- destroy() - Method in interface com.hazelcast.map.QueryCache
- 
Destroys this cache. 
- destroy() - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-  
- destroy() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-  
- destroy() - Method in interface com.hazelcast.nio.serialization.Serializer
- 
Called when instance is shutting down. 
- destroy() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingSocketReader
-  
- destroy() - Method in interface com.hazelcast.nio.tcp.SocketReader
- 
Destroys this SocketReader. 
- destroy() - Method in class com.hazelcast.nio.tcp.spinning.SpinningSocketReader
-  
- destroy(String) - Method in class com.hazelcast.replicatedmap.impl.PartitionContainer
-  
- destroy() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-  
- destroy() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- destroy() - Method in interface com.hazelcast.security.ICredentialsFactory
- 
- destroy() - Method in interface com.hazelcast.security.IPermissionPolicy
- 
- DESTROY - Static variable in class com.hazelcast.security.permission.InstancePermission
-  
- destroy() - Method in interface com.hazelcast.security.SecurityContext
- 
- destroy() - Method in class com.hazelcast.spi.AbstractDistributedObject
-  
- destroy() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
-  
- destroy() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
- 
The stop method is used to stop internal services, sockets or to destroy any
 kind of internal state. 
- destroy() - Method in class com.hazelcast.spi.discovery.impl.DefaultDiscoveryService
-  
- destroy() - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryService
- 
The start method is called on system startup to implement simple
 lifecycle management. 
- destroy() - Method in class com.hazelcast.web.ClusteredSessionService
- 
Destroy void. 
- destroy() - Method in class com.hazelcast.web.WebFilter
-  
- DESTROY_CACHE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- DESTROY_CACHE - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- DESTROY_PROXY - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-  
- destroyAllNearCaches() - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCacheManager
-  
- destroyAllNearCaches() - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheManager
- 
- destroyCache(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- destroyCacheOnAllMembers(String, String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- destroyConnection(Connection, Throwable) - Method in interface com.hazelcast.client.connection.ClientConnectionManager
- 
Destroys the connection
 Clears related resources of given connection. 
- destroyConnection(Connection, Throwable) - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-  
- destroyConnection(Connection) - Method in interface com.hazelcast.nio.ConnectionManager
- 
Destroys a connection. 
- destroyConnection(Connection) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- destroyDistributedObject(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- destroyDistributedObject(String) - Method in class com.hazelcast.collection.impl.collection.CollectionService
-  
- destroyDistributedObject(String) - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-  
- destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-  
- destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-  
- destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.idgen.IdGeneratorService
-  
- destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-  
- destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-  
- destroyDistributedObject(String) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-  
- destroyDistributedObject(String) - Method in class com.hazelcast.map.impl.MapService
-  
- destroyDistributedObject(String) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-  
- destroyDistributedObject(String) - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- destroyDistributedObject(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- destroyDistributedObject(String) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-  
- destroyDistributedObject(String, String) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-  
- destroyDistributedObject(String, String) - Method in interface com.hazelcast.spi.ProxyService
-  
- destroyDistributedObject(String) - Method in interface com.hazelcast.spi.RemoteService
- 
Destroys a distributed object. 
- destroyDistributedObject(String) - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicService
-  
- destroyDistributedObject(String) - Method in class com.hazelcast.topic.impl.TopicService
-  
- destroyDistributedObject(String) - Method in class com.hazelcast.transaction.impl.xa.XAService
-  
- destroyIndex(String) - Method in class com.hazelcast.query.impl.Indexes
-  
- destroyJobSupervisor(JobSupervisor) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-  
- destroyLocalDistributedObject(String, String, boolean) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-  
- destroyLocalMapStatsImpl(String) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
-  
- destroyMap(String) - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- destroyMap(MapContainer) - Method in class com.hazelcast.map.impl.PartitionContainer
-  
- destroyMapStores() - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- destroyNearCache(String) - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCacheManager
-  
- destroyNearCache(String) - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheManager
- 
Destroys  NearCache instance associated with given  name
 and also removes it. 
- destroyNearCache(String) - Method in class com.hazelcast.map.impl.nearcache.NearCacheProvider
-  
- DestroyProxyMessageTask - Class in com.hazelcast.client.impl.protocol.task
-  
- DestroyProxyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
-  
- destroySegments(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- destroySession(HazelcastHttpSession, boolean) - Method in class com.hazelcast.web.spring.SpringAwareWebFilter
-  
- destroySession(HazelcastHttpSession, boolean) - Method in class com.hazelcast.web.WebFilter
- 
Destroys a session, determining if it should be destroyed clusterwide automatically or via expiry. 
- destroyStore() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- difference(IntHashSet) - Method in class com.hazelcast.util.collection.IntHashSet
- 
Fast Path set difference for comparison with another IntHashSet. 
- difference(LongHashSet) - Method in class com.hazelcast.util.collection.LongHashSet
- 
Fast Path set difference for comparison with another LongHashSet. 
- dirtyEntryCount - Variable in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
-  
- disableWanReplicationEvent - Variable in class com.hazelcast.map.impl.operation.BaseRemoveOperation
- 
Used by wan-replication-service to disable wan-replication event publishing
 otherwise in active-active scenarios infinite loop of event forwarding can be seen. 
- disableWanReplicationEvent - Variable in class com.hazelcast.map.impl.operation.RemoveBackupOperation
-  
- discoverNodes() - Method in class com.hazelcast.jclouds.JCloudsDiscoveryStrategy
-  
- discoverNodes() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
- 
Returns a set of all discovered nodes based on the defined properties that were used
 to create the DiscoveryStrategy instance. 
- discoverNodes() - Method in class com.hazelcast.spi.discovery.impl.DefaultDiscoveryService
-  
- discoverNodes() - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryService
- 
Returns a discovered and filtered, if a  NodeFilter is setup, set of
 discovered nodes to connect to. 
- DiscoveryAddressProvider - Class in com.hazelcast.client.spi.impl.discovery
-  
- DiscoveryAddressProvider(DiscoveryService) - Constructor for class com.hazelcast.client.spi.impl.discovery.DiscoveryAddressProvider
-  
- DiscoveryAddressTranslator - Class in com.hazelcast.client.spi.impl.discovery
-  
- DiscoveryAddressTranslator(DiscoveryService) - Constructor for class com.hazelcast.client.spi.impl.discovery.DiscoveryAddressTranslator
-  
- DiscoveryConfig - Class in com.hazelcast.config
- 
This configuration class describes the top-level config of the discovery
 SPI and its discovery strategies. 
- DiscoveryConfig() - Constructor for class com.hazelcast.config.DiscoveryConfig
-  
- DiscoveryConfig(DiscoveryServiceProvider, NodeFilter, String, Collection<DiscoveryStrategyConfig>) - Constructor for class com.hazelcast.config.DiscoveryConfig
-  
- DiscoveryConfigReadOnly - Class in com.hazelcast.config
- 
- DiscoveryJoiner - Class in com.hazelcast.cluster.impl
-  
- DiscoveryJoiner(Node, DiscoveryService, boolean) - Constructor for class com.hazelcast.cluster.impl.DiscoveryJoiner
-  
- DiscoveryMode - Enum in com.hazelcast.spi.discovery.integration
- 
The  DiscoveryMode describes how the  DiscoveryStrategy is going
 to behave on discovery requests. 
- DiscoveryNode - Class in com.hazelcast.spi.discovery
- 
A DiscoveryNode describes a nodes addresses (private and if
 necessary a public one) as well as attributes assigned to this node. 
- DiscoveryNode() - Constructor for class com.hazelcast.spi.discovery.DiscoveryNode
-  
- discoveryService - Variable in class com.hazelcast.instance.Node
-  
- DiscoveryService - Interface in com.hazelcast.spi.discovery.integration
- 
The DiscoveryService interface defines the basic entry point
 into the Discovery SPI implementation. 
- DiscoveryServiceProvider - Interface in com.hazelcast.spi.discovery.integration
- 
The  DiscoveryServiceProvider interface provides the possibility to build  DiscoveryServices. 
- DiscoveryServiceSettings - Class in com.hazelcast.spi.discovery.integration
- 
- DiscoveryServiceSettings() - Constructor for class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-  
- DiscoveryStrategy - Interface in com.hazelcast.spi.discovery
- 
The DiscoveryStrategy itself is the actual implementation to discover
 nodes based on whatever environment is used to run the Hazelcast cloud. 
- DiscoveryStrategyConfig - Class in com.hazelcast.config
- 
This configuration class describes a  DiscoveryStrategy
 based on a parsed XML or configured manually using the config API 
- DiscoveryStrategyConfig(String) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
-  
- DiscoveryStrategyConfig(String, Map<String, Comparable>) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
-  
- DiscoveryStrategyConfig(DiscoveryStrategyFactory) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
-  
- DiscoveryStrategyConfig(DiscoveryStrategyFactory, Map<String, Comparable>) - Constructor for class com.hazelcast.config.DiscoveryStrategyConfig
-  
- DiscoveryStrategyFactory - Interface in com.hazelcast.spi.discovery
- 
The DiscoveryStrategyFactory is the entry point for strategy vendors. 
- dispatch(Packet) - Method in class com.hazelcast.spi.impl.packetdispatcher.impl.PacketDispatcherImpl
-  
- dispatch(Packet) - Method in interface com.hazelcast.spi.impl.packetdispatcher.PacketDispatcher
- 
Dispatches a packet to the appropriate service. 
- dispatchEvent(Object, CacheEventListener) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- dispatchEvent(ClientEvent, ClientListener) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- dispatchEvent(MembershipEvent, MembershipListener) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- dispatchEvent(CollectionEvent, ItemListener) - Method in class com.hazelcast.collection.impl.collection.CollectionService
-  
- dispatchEvent(QueueEvent, ItemListener) - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- dispatchEvent(Object, ListenerAdapter) - Method in class com.hazelcast.map.impl.event.MapEventPublishingService
-  
- dispatchEvent(Object, ListenerAdapter) - Method in class com.hazelcast.map.impl.MapService
-  
- dispatchEvent(MapReduceNotification) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-  
- dispatchEvent(EventData, EntryListener) - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- dispatchEvent(PartitionEvent, PartitionEventListener) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- dispatchEvent(QuorumEvent, QuorumListener) - Method in class com.hazelcast.quorum.impl.QuorumServiceImpl
-  
- dispatchEvent(Object, Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapEventPublishingService
-  
- dispatchEvent(Object, Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- dispatchEvent(E, T) - Method in interface com.hazelcast.spi.EventPublishingService
-  
- dispatchEvent(DistributedObjectEventPacket, Object) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-  
- dispatchEvent(Object, Object) - Method in class com.hazelcast.topic.impl.TopicService
-  
- Disposable - Interface in com.hazelcast.nio
- 
A Disposableis a container of data and/or resources that can be disposed.
 
- dispose() - Method in interface com.hazelcast.nio.Disposable
- 
Disposes this object and releases any data and/or resources associated
 with it. 
- disposeData(Data) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- disposeData(Data) - Method in interface com.hazelcast.internal.serialization.SerializationService
-  
- disposeDeferredBlocks() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
- 
This can be used to release unused resources. 
- disposeDeferredBlocks() - Method in interface com.hazelcast.map.impl.recordstore.Storage
-  
- DISTINCT_VALUES_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- DISTINCT_VALUES_MAPPER - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- DISTINCT_VALUES_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- distinctValues() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
- 
Returns an aggregation for selecting all distinct values.
 This aggregation is similar to:
 
- DistinctValuesAggregation<Key,Value,DistinctType> - Class in com.hazelcast.mapreduce.aggregation.impl
- 
The predefined distinct value aggregation. 
- DistinctValuesAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.DistinctValuesAggregation
-  
- DISTRIBUTED_OBJECT_DESTROYED - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- DISTRIBUTED_OBJECT_EVENT - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
-  
- DISTRIBUTED_OBJECT_INFO - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-  
- DistributedExecutorService - Class in com.hazelcast.executor.impl
-  
- DistributedExecutorService() - Constructor for class com.hazelcast.executor.impl.DistributedExecutorService
-  
- DistributedObject - Interface in com.hazelcast.core
- 
Base interface for all distributed objects. 
- distributedObject - Variable in class com.hazelcast.core.DistributedObjectEvent
-  
- distributedObjectCreated(DistributedObjectEvent) - Method in class com.hazelcast.client.impl.client.AddDistributedObjectListenerRequest
-  
- distributedObjectCreated(DistributedObjectEvent) - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
-  
- distributedObjectCreated(DistributedObjectEvent) - Method in interface com.hazelcast.core.DistributedObjectListener
- 
Invoked when a DistributedObject is created. 
- distributedObjectCreated(DistributedObjectEvent) - Method in class com.hazelcast.jmx.ManagementService
-  
- distributedObjectDestroyed(DistributedObjectEvent) - Method in class com.hazelcast.client.impl.client.AddDistributedObjectListenerRequest
-  
- distributedObjectDestroyed(DistributedObjectEvent) - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
-  
- distributedObjectDestroyed(DistributedObjectEvent) - Method in interface com.hazelcast.core.DistributedObjectListener
- 
Invoked when a DistributedObject is destroyed. 
- distributedObjectDestroyed(DistributedObjectEvent) - Method in class com.hazelcast.jmx.ManagementService
-  
- DistributedObjectDestroyedException - Exception in com.hazelcast.spi.exception
- 
- DistributedObjectDestroyedException(String) - Constructor for exception com.hazelcast.spi.exception.DistributedObjectDestroyedException
-  
- DistributedObjectDestroyOperation - Class in com.hazelcast.spi.impl.proxyservice.impl.operations
-  
- DistributedObjectDestroyOperation() - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.operations.DistributedObjectDestroyOperation
-  
- DistributedObjectDestroyOperation(String, String) - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.operations.DistributedObjectDestroyOperation
-  
- DistributedObjectEvent - Class in com.hazelcast.core
- 
DistributedObjectEvent is fired when a  DistributedObject
 is created or destroyed cluster-wide. 
- DistributedObjectEvent(DistributedObjectEvent.EventType, String, String, DistributedObject) - Constructor for class com.hazelcast.core.DistributedObjectEvent
- 
Constructs a DistributedObject Event. 
- DistributedObjectEvent.EventType - Enum in com.hazelcast.core
- 
Type of event. 
- DistributedObjectEventPacket - Class in com.hazelcast.spi.impl.proxyservice.impl
-  
- DistributedObjectEventPacket() - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectEventPacket
-  
- DistributedObjectEventPacket(DistributedObjectEvent.EventType, String, String) - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectEventPacket
-  
- DistributedObjectFuture - Class in com.hazelcast.spi.impl.proxyservice.impl
-  
- DistributedObjectFuture() - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectFuture
-  
- DistributedObjectInfo - Class in com.hazelcast.client.impl.client
-  
- DistributedObjectInfo() - Constructor for class com.hazelcast.client.impl.client.DistributedObjectInfo
-  
- DistributedObjectInfo(String, String) - Constructor for class com.hazelcast.client.impl.client.DistributedObjectInfo
-  
- DistributedObjectListener - Interface in com.hazelcast.core
- 
DistributedObjectListener notifies when a  DistributedObject
 is created or destroyed cluster-wide. 
- divideByAndCeilToInt(double, int) - Static method in class com.hazelcast.util.QuickMath
- 
Divide d by k and return the smallest integer greater than or equal to the result. 
- divideByAndCeilToLong(double, int) - Static method in class com.hazelcast.util.QuickMath
- 
Divide d by k and return the smallest integer greater than or equal to the result. 
- divideByAndRoundToInt(double, int) - Static method in class com.hazelcast.util.QuickMath
- 
Divide d by k and return the int value closest to the result. 
- divideByAndRoundToLong(double, int) - Static method in class com.hazelcast.util.QuickMath
- 
Divide d by k and return the long value closest to the result. 
- DO_NOT_REDUCE - Static variable in class com.hazelcast.query.impl.getters.AbstractMultiValueGetter
-  
- doActualRead(ByteBuffer) - Method in class com.hazelcast.internal.ascii.rest.HttpPostCommand
-  
- DOC_VERSION - Static variable in class com.hazelcast.aws.impl.Constants
-  
- doEviction() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- doEviction() - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheRecordStore
- 
- doEvictionIfRequired() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- doEvictionIfRequired() - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheRecordStore
- 
- doExpiration() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.BaseHeapNearCacheRecordStore
-  
- doExpiration() - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheRecordStore
- 
Performs expiration and evicts expired records. 
- doFilter(EventFilter, Data, Object, Object, EntryEventType, String) - Method in class com.hazelcast.map.impl.event.MapEventPublisherImpl
-  
- doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class com.hazelcast.web.WebFilter
-  
- doJoin() - Method in class com.hazelcast.cluster.impl.AbstractJoiner
-  
- doJoin() - Method in class com.hazelcast.cluster.impl.MulticastJoiner
-  
- doJoin() - Method in class com.hazelcast.cluster.impl.TcpIpJoiner
-  
- doMatch(String, String, int) - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
-  
- domLevel3 - Variable in class com.hazelcast.config.AbstractXmlConfigHelper
-  
- done() - Method in class com.hazelcast.nio.Packet
-  
- done() - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
- 
Protected method invoked when this task transitions to state
 isDone(only normally - in case of cancellation cancelled() is invoked)
 The default implementation does nothing.
 
- doneProcessing() - Method in class com.hazelcast.partition.MigrationInfo
-  
- doPostEvictionOperations(Data, Object, boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- doPutRecord(Data, R) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- doPutRecord(Data, R, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- doRemoveRecord(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- doRemoveRecord(Data, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- doShutdown() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- DOUBLE_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
-  
- DOUBLE_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
-  
- DOUBLE_AVG_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- DOUBLE_AVG_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- DOUBLE_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
-  
- DOUBLE_MAX_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- DOUBLE_MAX_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- DOUBLE_MIN_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- DOUBLE_MIN_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- DOUBLE_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
- 
Double size in bytes 
- DOUBLE_SUM_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- DOUBLE_SUM_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- doubleAvg() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
- 
Returns an aggregation to calculate the double average of all supplied values.
 This aggregation is similar to:
 
- DoubleAvgAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
- 
The predefined average aggregation for values of type double. 
- DoubleAvgAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.DoubleAvgAggregation
-  
- DoubleGauge - Interface in com.hazelcast.internal.metrics
- 
A DoubleGauge is {link Metric} where a particular double value is read instantaneous. 
- doubleMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
- 
Returns an aggregation to find the double maximum of all supplied values.
 This aggregation is similar to:
 
- DoubleMaxAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
- 
The predefined maximum aggregation for values of type double. 
- DoubleMaxAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.DoubleMaxAggregation
-  
- doubleMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
- 
Returns an aggregation to find the double minimum of all supplied values.
 This aggregation is similar to:
 
- DoubleMinAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
- 
The predefined minimum aggregation for values of type double. 
- DoubleMinAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.DoubleMinAggregation
-  
- DoubleProbeFunction<S> - Interface in com.hazelcast.internal.metrics
- 
A  ProbeFunction that provides a double value and can be used to create a probe using
  MetricsRegistry#register(Object, String, DoubleProbeFunction)
- doubleSum() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
- 
Returns an aggregation to calculate the double sum of all supplied values.
 This aggregation is similar to:
 
- DoubleSumAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
- 
The predefined sum aggregation for values of type double. 
- DoubleSumAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.DoubleSumAggregation
-  
- drain(int) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- DRAIN - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-  
- DRAIN - Static variable in class com.hazelcast.collection.impl.queue.QueuePortableHook
-  
- drain(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-  
- drain() - Method in class com.hazelcast.jmx.SemaphoreMBean
-  
- DRAIN_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-  
- DRAIN_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-  
- DRAIN_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-  
- DrainBackupOperation - Class in com.hazelcast.collection.impl.queue.operations
- 
This class stores items' id when DrainOperation run. 
- DrainBackupOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.DrainBackupOperation
-  
- DrainBackupOperation(String, Set<Long>) - Constructor for class com.hazelcast.collection.impl.queue.operations.DrainBackupOperation
-  
- DrainBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
-  
- DrainBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.DrainBackupOperation
-  
- DrainBackupOperation(String, int, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.DrainBackupOperation
-  
- drainFromBackup(Set<Long>) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- DrainOperation - Class in com.hazelcast.collection.impl.queue.operations
- 
This class drain items according to drain condition. 
- DrainOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.DrainOperation
-  
- DrainOperation(String, int) - Constructor for class com.hazelcast.collection.impl.queue.operations.DrainOperation
-  
- DrainOperation - Class in com.hazelcast.concurrent.semaphore.operations
-  
- DrainOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.DrainOperation
-  
- DrainOperation(String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.DrainOperation
-  
- drainPermits() - Method in class com.hazelcast.client.proxy.ClientSemaphoreProxy
-  
- drainPermits() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-  
- drainPermits() - Method in interface com.hazelcast.core.ISemaphore
- 
Acquires and returns all permits that are immediately available. 
- DrainRequest - Class in com.hazelcast.collection.impl.queue.client
- 
- DrainRequest() - Constructor for class com.hazelcast.collection.impl.queue.client.DrainRequest
-  
- DrainRequest(String, int) - Constructor for class com.hazelcast.collection.impl.queue.client.DrainRequest
-  
- DrainRequest - Class in com.hazelcast.concurrent.semaphore.client
-  
- DrainRequest() - Constructor for class com.hazelcast.concurrent.semaphore.client.DrainRequest
-  
- DrainRequest(String) - Constructor for class com.hazelcast.concurrent.semaphore.client.DrainRequest
-  
- drainTo(Collection<? super E>) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-  
- drainTo(Collection<? super E>, int) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-  
- drainTo(Collection<? super E>) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
-  
- drainTo(Collection<? super E>, int) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
-  
- drainTo(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
- 
Removes all elements from this queue and adds them to the given collection. 
- dumpAllThreads() - Static method in class com.hazelcast.internal.management.ThreadDumpGenerator
-  
- dumpDeadlocks() - Static method in class com.hazelcast.internal.management.ThreadDumpGenerator
-  
- dumpPerformanceMetrics(StringBuffer) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- dumpPerformanceMetrics(StringBuffer) - Method in interface com.hazelcast.spi.OperationService
- 
Deprecated. 
- DUPLICATE_INSTANCE_NAME - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- DuplicateDetectingMultiResult - Class in com.hazelcast.query.impl
-  
- DuplicateDetectingMultiResult() - Constructor for class com.hazelcast.query.impl.DuplicateDetectingMultiResult
-  
- DuplicateInstanceNameException - Exception in com.hazelcast.core
- 
Thrown when a duplicate instance name is detected. 
- DuplicateInstanceNameException(String) - Constructor for exception com.hazelcast.core.DuplicateInstanceNameException
- 
Returns the message when a duplicate instance name is detected. 
- durationMs - Variable in class com.hazelcast.internal.management.dto.SlowOperationInvocationDTO
-  
- GarbageCollectionMetricSet - Class in com.hazelcast.internal.metrics.metricsets
- 
- GarbageCollectorStats - Interface in com.hazelcast.memory
- 
Garbage collector statistics for the JVM which current HazelcastInstance
 belongs to. 
- GCStatsSupport - Class in com.hazelcast.memory
- 
Used to gather garbage collection statistics 
- generate(Config) - Method in class com.hazelcast.config.ConfigXmlGenerator
- 
Generates the XML string based on some Config. 
- generateInterceptorId(String, MapInterceptor) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
-  
- GENERIC_ERROR - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-  
- GENERIC_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
-  
- GENERIC_PARTITION_ID - Static variable in class com.hazelcast.spi.Operation
-  
- GenericClientExceptionConverter - Class in com.hazelcast.client.impl.exceptionconverters
- 
- GenericClientExceptionConverter() - Constructor for class com.hazelcast.client.impl.exceptionconverters.GenericClientExceptionConverter
-  
- GenericError - Class in com.hazelcast.client.impl.client
-  
- GenericError() - Constructor for class com.hazelcast.client.impl.client.GenericError
-  
- GenericError(String, String, int) - Constructor for class com.hazelcast.client.impl.client.GenericError
-  
- GenericError(String, String, String, int) - Constructor for class com.hazelcast.client.impl.client.GenericError
-  
- GenericOperation - Class in com.hazelcast.ringbuffer.impl.operations
-  
- GenericOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.GenericOperation
-  
- GenericOperation(String, byte) - Constructor for class com.hazelcast.ringbuffer.impl.operations.GenericOperation
-  
- GenericOperationThread - Class in com.hazelcast.spi.impl.operationexecutor.classic
- 
- GenericOperationThread(String, int, ScheduleQueue, ILogger, HazelcastThreadGroup, NodeExtension, OperationRunner) - Constructor for class com.hazelcast.spi.impl.operationexecutor.classic.GenericOperationThread
-  
- GET - Static variable in class com.hazelcast.aws.impl.Constants
-  
- get(K, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
- 
Retrieves the mapped value of the given key using a custom ExpiryPolicy.
 
- get(Data, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- GET - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- get() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorResult
-  
- GET - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- get(K) - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- get(Data, ExpiryPolicy) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Gets the value to which the specified key is mapped,
 or nullif this cache contains no mapping for the key.
 
- get(K) - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache
-  
- get(K) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- get(K) - Method in interface com.hazelcast.cache.impl.nearcache.NearCache
- 
Gets the value associated with the given key.
 
- get(K) - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheRecordStore
- 
Gets the value associated with the given key.
 
- get(K) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- get(ClientType) - Static method in class com.hazelcast.client.impl.exceptionconverters.ClientExceptionConverters
-  
- get(K) - Method in class com.hazelcast.client.map.impl.nearcache.ClientHeapNearCache
-  
- get() - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-  
- get() - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-  
- get(int) - Method in class com.hazelcast.client.proxy.ClientListProxy
-  
- get(Object) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- get(K) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-  
- get(Object) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-  
- get(Object) - Method in class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-  
- get(K) - Method in class com.hazelcast.client.proxy.txn.ClientTxnMultiMapProxy
-  
- get() - Method in class com.hazelcast.client.spi.impl.ClientInvocationFuture
-  
- get(long, TimeUnit) - Method in class com.hazelcast.client.spi.impl.ClientInvocationFuture
-  
- get(Object) - Method in class com.hazelcast.client.txn.proxy.ClientTxnMapProxy
-  
- get(K) - Method in class com.hazelcast.client.txn.proxy.ClientTxnMultiMapProxy
-  
- get() - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-  
- get(long, TimeUnit) - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-  
- get(int) - Method in class com.hazelcast.collection.impl.list.ListContainer
-  
- get(int) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
-  
- get() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
-  
- GET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-  
- get() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- get() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceContainer
-  
- GET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-  
- get() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- get(String) - Static method in enum com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
-  
- get(Object) - Method in interface com.hazelcast.core.BaseMap
- 
Returns the value for the specified key, or nullif this map does not contain this key.
 
- get(K) - Method in interface com.hazelcast.core.BaseMultiMap
- 
Returns the collection of values associated with the key. 
- get() - Method in interface com.hazelcast.core.IAtomicLong
- 
Gets the current value. 
- get() - Method in interface com.hazelcast.core.IAtomicReference
- 
Gets the current value. 
- get(Object) - Method in interface com.hazelcast.core.IMap
- 
Returns the value for the specified key, or nullif this map does not contain this key.
 
- get(K) - Method in interface com.hazelcast.core.MultiMap
- 
Returns the collection of values associated with the key. 
- get(Object) - Method in interface com.hazelcast.core.TransactionalMap
- 
- get(K) - Method in interface com.hazelcast.core.TransactionalMultiMap
- 
Returns the collection of values associated with the key. 
- get(Object, long) - Method in class com.hazelcast.hibernate.access.AbstractAccessDelegate
-  
- get(Object, long) - Method in interface com.hazelcast.hibernate.access.AccessDelegate
- 
Attempt to retrieve an object from the cache. 
- get(Object, long) - Method in class com.hazelcast.hibernate.distributed.IMapRegionCache
-  
- get(Object, long) - Method in class com.hazelcast.hibernate.local.LocalRegionCache
-  
- get(Object, long) - Method in class com.hazelcast.hibernate.region.CollectionRegionAccessStrategyAdapter
-  
- get(Object, long) - Method in class com.hazelcast.hibernate.region.EntityRegionAccessStrategyAdapter
-  
- get(Object, long) - Method in class com.hazelcast.hibernate.region.NaturalIdRegionAccessStrategyAdapter
-  
- get(Object, long) - Method in interface com.hazelcast.hibernate.RegionCache
-  
- get(String, String) - Method in interface com.hazelcast.internal.ascii.TextCommandService
-  
- get(String, String) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- get(S) - Method in interface com.hazelcast.internal.metrics.DoubleProbeFunction
- 
Gets the current value of the source object. 
- get(S) - Method in interface com.hazelcast.internal.metrics.LongProbeFunction
- 
Gets the current value of the source object as a long. 
- get() - Method in class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolThreadLocal
-  
- get() - Method in class com.hazelcast.jmx.suppliers.LocalMapStatsSupplier
-  
- get() - Method in class com.hazelcast.jmx.suppliers.LocalMultiMapStatsSupplier
-  
- get() - Method in class com.hazelcast.jmx.suppliers.LocalQueueStatsSupplier
-  
- get() - Method in interface com.hazelcast.jmx.suppliers.StatsSupplier
-  
- GET - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-  
- GET - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- get(Data) - Method in class com.hazelcast.map.impl.nearcache.NearCacheImpl
-  
- get(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- get(Data, boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- get(Data, boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
- 
- get(K) - Method in interface com.hazelcast.map.impl.recordstore.Storage
-  
- get(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-  
- get(Object) - Method in interface com.hazelcast.map.QueryCache
-  
- GET - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- GET - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-  
- get(K) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-  
- get(K) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
-  
- get(byte) - Static method in enum com.hazelcast.nio.serialization.FieldType
-  
- get(String) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
-  
- get(String) - Method in class com.hazelcast.query.EntryObject
-  
- GET - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-  
- get(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-  
- get(Object) - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
-  
- get(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- get(Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-  
- get(int) - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
-  
- get(int) - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
-  
- get(int) - Method in interface com.hazelcast.ringbuffer.ReadResultSet
- 
Gets the item at the given index. 
- get(int) - Method in interface com.hazelcast.security.Parameters
-  
- get() - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-  
- get(long, TimeUnit) - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
- 
PLEASE NOTE: It's legal to override this method, but please bear in mind that you should call super.get() or
 implement the done() and cancelled() callbacks to be notified if this future gets done or cancelled. 
- get(long) - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
- 
Gets the invocation for the given call id. 
- get() - Method in class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectFuture
-  
- get(int) - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
-  
- get(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
-  
- get(Object, Class<T>) - Method in class com.hazelcast.spring.cache.HazelcastCache
-  
- get(Object) - Method in interface com.hazelcast.transaction.impl.Transaction
-  
- get(Object) - Method in class com.hazelcast.transaction.impl.TransactionImpl
-  
- get(Object) - Method in class com.hazelcast.transaction.impl.TransactionLog
-  
- get(Object) - Method in class com.hazelcast.transaction.impl.xa.XATransaction
-  
- get(int, int) - Method in class com.hazelcast.util.collection.BiInt2ObjectMap
- 
Retrieve a value from the map. 
- get(Object) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
- get(int) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
- 
- get(K) - Method in class com.hazelcast.util.collection.InternalMultiMap
- 
Return collection of values associated with a given key 
- get(long) - Method in class com.hazelcast.util.collection.Long2LongHashMap
-  
- get(Object) - Method in class com.hazelcast.util.collection.Long2LongHashMap
- get(Object) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
- get(long) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
- 
- get(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
- 
Returns the value to which the specified key is mapped,
 or nullif this map contains no mapping for the key.
 
- get() - Method in interface com.hazelcast.util.counters.Counter
- 
Gets the current value of the counter. 
- get() - Method in class com.hazelcast.util.counters.MwCounter
-  
- get() - Method in class com.hazelcast.util.executor.CompletedFuture
-  
- get(long, TimeUnit) - Method in class com.hazelcast.util.executor.CompletedFuture
-  
- get() - Method in class com.hazelcast.util.executor.DelegatingFuture
-  
- get(long, TimeUnit) - Method in class com.hazelcast.util.executor.DelegatingFuture
-  
- get() - Method in interface com.hazelcast.util.function.Supplier
-  
- get(T) - Method in class com.hazelcast.util.ItemCounter
- 
Get current counter for an item item 
- get(K) - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
-  
- GET_ALL - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- GET_ALL - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- GET_ALL - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- GET_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- GET_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-  
- GET_ALL_FACTORY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- GET_AND_ADD - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-  
- GET_AND_ALTER - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-  
- GET_AND_ALTER - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-  
- GET_AND_REMOVE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- GET_AND_REMOVE - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- GET_AND_REPLACE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- GET_AND_REPLACE - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- GET_AND_SET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-  
- GET_AND_SET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-  
- GET_ATTRIBUTE - Static variable in class com.hazelcast.web.WebDataSerializerHook
- 
The constant GET_ATTRIBUTE. 
- GET_ATTRIBUTE_NAMES - Static variable in class com.hazelcast.web.WebDataSerializerHook
- 
The constant GET_ATTRIBUTE_NAMES. 
- GET_CACHE_TIME_TAKEN_NANOS - Static variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- GET_CONFIG - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- GET_CONFIG - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- GET_COUNT_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-  
- GET_DISTRIBUTED_OBJECT_INFO - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-  
- GET_ENTRY_VIEW - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- GET_LOCAL_MAP_STATS - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- GET_LOCK_COUNT - Static variable in class com.hazelcast.concurrent.lock.client.LockPortableHook
-  
- GET_LOCK_COUNT - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
-  
- GET_MEMBER_LIST - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-  
- GET_PARTITIONS - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-  
- GET_REMAINING_LEASE - Static variable in class com.hazelcast.concurrent.lock.client.LockPortableHook
-  
- GET_REMAINING_LEASETIME - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
-  
- GET_RESPONSE - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-  
- GET_RESULT_OPERATION - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-  
- GET_SESSION_STATE - Static variable in class com.hazelcast.web.WebDataSerializerHook
- 
The constant GET_SESSION_STATE. 
- getAccessHit() - Method in interface com.hazelcast.cache.CacheEntryView
- 
Gets the count of how many time this cache entry has been accessed. 
- getAccessHit() - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- getAccessHit() - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
-  
- getAccessHit() - Method in class com.hazelcast.cache.impl.merge.entry.LazyCacheEntryView
-  
- getAccessHit() - Method in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-  
- getAccessHit() - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-  
- getAccessHit() - Method in interface com.hazelcast.internal.eviction.Evictable
- 
- getAccessKey() - Method in class com.hazelcast.config.AwsConfig
- 
Gets the access key to access AWS. 
- getAccessor() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.HeapNearCacheRecordMap.EvictableSamplingEntry
-  
- getAccessor() - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap.EvictableSamplingEntry
-  
- getAccessor() - Method in interface com.hazelcast.internal.eviction.EvictionCandidate
- 
The accessor (key or id) of  Evictable entry or record or whatever. 
- getAccessTime() - Method in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-  
- getAccessTime() - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-  
- getAccessTime() - Method in interface com.hazelcast.internal.eviction.Evictable
- 
Gets the latest access time difference of this  Evictable in milliseconds. 
- getAcknowledgeType() - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- getAcknowledgeType() - Method in class com.hazelcast.wan.WanReplicationEvent
-  
- getAcquireTime() - Method in interface com.hazelcast.concurrent.lock.LockResource
-  
- getActions() - Method in class com.hazelcast.config.PermissionConfig
-  
- getActions() - Method in class com.hazelcast.security.permission.AllPermissions
-  
- getActions() - Method in class com.hazelcast.security.permission.InstancePermission
-  
- getActions() - Method in class com.hazelcast.security.permission.TransactionPermission
-  
- getActiveConnectionCount() - Method in class com.hazelcast.jmx.ConnectionManagerMBean
-  
- getActiveConnectionCount() - Method in interface com.hazelcast.nio.ConnectionManager
- 
Gets the number of active connections. 
- getActiveConnectionCount() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- getActiveConnections() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- getActiveMigrations() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getActiveMigrations() - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- getActivePartitionCount() - Method in class com.hazelcast.internal.management.dto.PartitionServiceBeanDTO
-  
- getActivePartitionCount() - Method in class com.hazelcast.jmx.PartitionServiceMBean
-  
- getActiveRegistrations(String) - Method in class com.hazelcast.client.spi.impl.listener.ClientListenerServiceImpl
-  
- getActiveRegistrations(String) - Method in class com.hazelcast.client.spi.impl.listener.ClientNonSmartListenerService
-  
- getActiveRegistrations(String) - Method in class com.hazelcast.client.spi.impl.listener.ClientSmartListenerService
-  
- getActualDelayMillis() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
-  
- getActualDelaySeconds() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
-  
- getAddress() - Method in class com.hazelcast.cluster.impl.JoinMessage
-  
- getAddress() - Method in class com.hazelcast.cluster.MemberInfo
-  
- getAddress() - Method in interface com.hazelcast.core.Member
- 
Returns the Address of this Member. 
- getAddress() - Method in class com.hazelcast.instance.AbstractMember
-  
- getAddress() - Method in class com.hazelcast.internal.management.ManagementCenterIdentifier
-  
- getAddress() - Method in class com.hazelcast.mapreduce.impl.notification.MemberAwareMapReduceNotification
-  
- getAddress() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- getAddress() - Method in interface com.hazelcast.monitor.MemberState
-  
- getAddress() - Method in class com.hazelcast.util.AddressUtil.AddressHolder
-  
- getAddress() - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
-  
- getAddresses() - Method in class com.hazelcast.aws.AWSClient
-  
- getAddresses() - Method in class com.hazelcast.client.config.ClientConfig
- 
Deprecated. 
- getAddresses() - Method in class com.hazelcast.client.config.ClientNetworkConfig
- 
Returns the list of candidate addresses that client will use to establish initial connection 
- getAddressHolder(String) - Static method in class com.hazelcast.util.AddressUtil
-  
- getAddressHolder(String, int) - Static method in class com.hazelcast.util.AddressUtil
-  
- getAddressMatcher(String) - Static method in class com.hazelcast.util.AddressUtil
- 
Gets an AddressMatcher for a given addresses. 
- getAdjustedTTLSeconds(int) - Method in interface com.hazelcast.internal.ascii.TextCommandService
-  
- getAdjustedTTLSeconds(int) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- getAlgorithm() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-  
- getAll(Set<? extends K>, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
- 
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. 
- getAll(Set<Data>, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- getAll(Set<? extends K>) - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- getAll(Set<Data>, ExpiryPolicy) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Gets a collection of entries from the store, returning them as
  Map of the values associated with the set of keys requested. 
- getAll(Set<? extends K>) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- getAll(Set<K>) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- getAll() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- getAll(Set<K>) - Method in interface com.hazelcast.core.IMap
- 
Returns the entries for the given keys. 
- getAll(Set<K>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- getAll(Set<Data>) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- getAll(Set<Data>) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- getAll(Set<K>) - Method in interface com.hazelcast.map.QueryCache
-  
- getAllDistributedObjects() - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-  
- getAllDistributedObjects() - Method in interface com.hazelcast.spi.ProxyService
-  
- getAllDone(Collection<Future>) - Static method in class com.hazelcast.util.FutureUtil
- 
Get all futures that are done 
- getAllHazelcastClients() - Static method in class com.hazelcast.client.HazelcastClient
- 
Gets an immutable collection of all client HazelcastInstances created in this JVM. 
- getAllHazelcastInstances() - Static method in class com.hazelcast.core.Hazelcast
- 
Returns all active/running HazelcastInstances on this JVM. 
- getAllHazelcastInstances() - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
-  
- getAllHazelcastInstances() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
- 
- getAllInternal(Map<Integer, List<Data>>, Map<K, V>) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- getAllInternal(Map<Integer, List<Data>>, Map<K, V>) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- getAllInternal(Data) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-  
- getAllKeys() - Method in class com.hazelcast.mapreduce.KeyValueSource
- 
- getAllKeys0() - Method in class com.hazelcast.mapreduce.KeyValueSource
- 
This method is meant to be overridden to implement collecting of all clusterwide available keys
 and return them from  KeyValueSource.getAllKeys(). 
- getAllLocks() - Method in interface com.hazelcast.concurrent.lock.LockService
-  
- getAllLocks() - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-  
- getAllObjectInternal(List<Data>, List) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- getAllocatorType() - Method in class com.hazelcast.config.NativeMemoryConfig
-  
- GetAllOperation - Class in com.hazelcast.map.impl.operation
-  
- GetAllOperation() - Constructor for class com.hazelcast.map.impl.operation.GetAllOperation
-  
- GetAllOperation(String, List<Data>) - Constructor for class com.hazelcast.map.impl.operation.GetAllOperation
-  
- GetAllOperation - Class in com.hazelcast.multimap.impl.operations
-  
- GetAllOperation() - Constructor for class com.hazelcast.multimap.impl.operations.GetAllOperation
-  
- GetAllOperation(String, Data) - Constructor for class com.hazelcast.multimap.impl.operations.GetAllOperation
-  
- getAllPartitionIds() - Method in class com.hazelcast.map.impl.query.MapQueryEngineImpl
-  
- getAllReplicatedRecordStores(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- GetAllRequest - Class in com.hazelcast.multimap.impl.client
-  
- GetAllRequest() - Constructor for class com.hazelcast.multimap.impl.client.GetAllRequest
-  
- GetAllRequest(String, Data) - Constructor for class com.hazelcast.multimap.impl.client.GetAllRequest
-  
- GetAllRequest(String, Data, long) - Constructor for class com.hazelcast.multimap.impl.client.GetAllRequest
-  
- getAllTextConnections() - Method in interface com.hazelcast.nio.ConnectionManager
- 
Gets the number of text connections (rest/memcache) 
- getAllTextConnections() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- getAllThreads() - Static method in class com.hazelcast.internal.management.ThreadDumpGenerator
-  
- getAnchor() - Method in class com.hazelcast.query.PagingPredicate
- 
Retrieve the anchor object which is the last value object on the previous page. 
- getAndAdd(long) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-  
- getAndAdd(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
-  
- getAndAdd(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- getAndAdd(long) - Method in interface com.hazelcast.core.IAtomicLong
- 
Atomically adds the given value to the current value. 
- getAndAdd(long) - Method in class com.hazelcast.jmx.AtomicLongMBean
-  
- GetAndAddOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-  
- GetAndAddOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
-  
- GetAndAddOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
-  
- GetAndAddRequest - Class in com.hazelcast.concurrent.atomiclong.client
-  
- GetAndAddRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.GetAndAddRequest
-  
- GetAndAddRequest(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.client.GetAndAddRequest
-  
- getAndAlter(IFunction<Long, Long>) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-  
- getAndAlter(IFunction<E, E>) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-  
- getAndAlter(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- getAndAlter(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- getAndAlter(IFunction<Long, Long>) - Method in interface com.hazelcast.core.IAtomicLong
- 
Alters the currently stored value by applying a function on it on and gets the old value. 
- getAndAlter(IFunction<E, E>) - Method in interface com.hazelcast.core.IAtomicReference
- 
Alters the currently stored reference by applying a function on it on and gets the old value. 
- GetAndAlterOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-  
- GetAndAlterOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndAlterOperation
-  
- GetAndAlterOperation(String, IFunction<Long, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndAlterOperation
-  
- GetAndAlterOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-  
- GetAndAlterOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetAndAlterOperation
-  
- GetAndAlterOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetAndAlterOperation
-  
- GetAndAlterRequest - Class in com.hazelcast.concurrent.atomiclong.client
-  
- GetAndAlterRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.GetAndAlterRequest
-  
- GetAndAlterRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomiclong.client.GetAndAlterRequest
-  
- GetAndAlterRequest - Class in com.hazelcast.concurrent.atomicreference.client
-  
- GetAndAlterRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.GetAndAlterRequest
-  
- GetAndAlterRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.GetAndAlterRequest
-  
- getAndIncrement() - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-  
- getAndIncrement() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- getAndIncrement() - Method in interface com.hazelcast.core.IAtomicLong
- 
Atomically increments the current value by one. 
- getAndIncrement() - Method in class com.hazelcast.jmx.AtomicLongMBean
-  
- getAndPut(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
- 
Associates the specified value with the specified key in this cache using a custom ExpiryPolicy,
 returning an existing value if one existed.
 
- getAndPut(Data, Object, ExpiryPolicy, String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- getAndPut(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- getAndPut(Data, Object, ExpiryPolicy, String, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Associates the specified value with the specified key in this cache,
 returning an existing value if one existed. 
- getAndPut(K, V) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- getAndPutAsync(K, V) - Method in interface com.hazelcast.cache.ICache
- 
Asynchronously associates the specified value with the specified key in this cache,
 returning an existing value if one existed. 
- getAndPutAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
- 
Asynchronously associates the specified value with the specified key in this cache,
 returning an existing value if one existed using a custom ExpiryPolicy.
 
- getAndRemove(Data, String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- getAndRemove(Data, String, int, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- getAndRemove(K) - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- getAndRemove(Data, String, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Atomically removes the entry for a key only if it is currently mapped to some
 value. 
- getAndRemove(K) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- getAndRemoveAsync(K) - Method in interface com.hazelcast.cache.ICache
- 
Asynchronously removes the entry for a key and returns the previously assigned value or null
 if no value was assigned. 
- getAndReplace(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
- 
Atomically replaces the assigned value of the given key by the specified value using a
 custom ExpiryPolicyand returns the previously assigned value.
 
- getAndReplace(Data, Object, ExpiryPolicy, String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- getAndReplace(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- getAndReplace(Data, Object, ExpiryPolicy, String, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Atomically replaces the value for a given key if and only if there is a
 value currently mapped by the key. 
- getAndReplace(K, V) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- getAndReplaceAsync(K, V) - Method in interface com.hazelcast.cache.ICache
- 
Asynchronously replaces the assigned value of the given key by the specified value and returns
 the previously assigned value. 
- getAndReplaceAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
- 
Asynchronously replaces the assigned value of the given key by the specified value using a
 custom ExpiryPolicyand returns the previously assigned value.
 
- getAndSet(long) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-  
- getAndSet(E) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-  
- getAndSet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
-  
- getAndSet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- getAndSet(Data) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceContainer
-  
- getAndSet(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- getAndSet(long) - Method in interface com.hazelcast.core.IAtomicLong
- 
Atomically sets the given value and returns the old value. 
- getAndSet(E) - Method in interface com.hazelcast.core.IAtomicReference
- 
Gets the old value and sets the new value. 
- getAndSet(long) - Method in class com.hazelcast.jmx.AtomicLongMBean
-  
- getAndSet(T, long) - Method in class com.hazelcast.util.ItemCounter
- 
Set counter for item and return previous value 
- GetAndSetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-  
- GetAndSetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
-  
- GetAndSetOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
-  
- GetAndSetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-  
- GetAndSetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
-  
- GetAndSetOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
-  
- GetAndSetRequest - Class in com.hazelcast.concurrent.atomiclong.client
-  
- GetAndSetRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.GetAndSetRequest
-  
- GetAndSetRequest(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.client.GetAndSetRequest
-  
- GetAndSetRequest - Class in com.hazelcast.concurrent.atomicreference.client
-  
- GetAndSetRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.GetAndSetRequest
-  
- GetAndSetRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.GetAndSetRequest
-  
- getArray(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
- 
Returns a field in a Json object as an array. 
- getArray(JsonObject, String, JsonArray) - Static method in class com.hazelcast.util.JsonUtil
- 
Returns a field in a Json object as an array. 
- getAsDataList() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
- 
This method triggers store load. 
- getAsReadOnly() - Method in class com.hazelcast.config.CacheConfig
- 
Gets immutable version of this cache configuration. 
- getAsReadOnly() - Method in class com.hazelcast.config.CacheEvictionConfig
- 
Deprecated. 
- getAsReadOnly() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Gets the immutable version of this simple cache config. 
- getAsReadOnly() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.CollectionConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.DiscoveryConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.EntryListenerConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.EvictionConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.ExecutorConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.ItemListenerConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.JobTrackerConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.ListConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.ListenerConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.MapAttributeConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.MapConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.MapIndexConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.MapStoreConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.MaxSizeConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.MultiMapConfig
- 
Gets the immutable version of this MultiMap config. 
- getAsReadOnly() - Method in class com.hazelcast.config.NearCacheConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.PartitioningStrategyConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.PredicateConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.QueryCacheConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.QueueConfig
- 
Returns a read only copy of the queue configuration. 
- getAsReadOnly() - Method in class com.hazelcast.config.QueueStoreConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.ReliableTopicConfig
- 
Returns a readonly version of the ReliableTopicConfig. 
- getAsReadOnly() - Method in class com.hazelcast.config.ReplicatedMapConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.RingbufferConfig
- 
Creates a readonly copy of this RingbufferConfig. 
- getAsReadOnly() - Method in class com.hazelcast.config.SemaphoreConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.SetConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.TopicConfig
-  
- getAsReadOnly() - Method in class com.hazelcast.config.WanReplicationRef
-  
- getAssignment() - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentResult
-  
- getAsync(K) - Method in interface com.hazelcast.cache.ICache
- 
Asynchronously retrieves the mapped value of the given key using a custom
 ExpiryPolicy.
 
- getAsync(K, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
- 
Asynchronously gets an entry from cache using a custom ExpiryPolicy.
 
- getAsync(K) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- getAsync(K) - Method in interface com.hazelcast.core.IMap
- 
Asynchronously gets the given key. 
- getAsync(K) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- getAsyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionBackupAwareOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.collection.impl.queue.operations.QueueBackupAwareOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- getAsyncBackupCount() - Method in interface com.hazelcast.concurrent.lock.LockStoreInfo
-  
- getAsyncBackupCount() - Method in class com.hazelcast.concurrent.lock.operations.BaseLockOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupAwareOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-  
- getAsyncBackupCount() - Method in class com.hazelcast.config.CacheConfig
- 
Gets the number of asynchronous backups for this  ICache. 
- getAsyncBackupCount() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Gets the number of asynchronous backups for this  ICache. 
- getAsyncBackupCount() - Method in class com.hazelcast.config.CollectionConfig
- 
Gets the number of asynchronous backups. 
- getAsyncBackupCount() - Method in class com.hazelcast.config.MapConfig
- 
Returns the asynchronous backup count for this  IMap. 
- getAsyncBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
- 
Gets the number of asynchronous backups for this MultiMap. 
- getAsyncBackupCount() - Method in class com.hazelcast.config.QueueConfig
- 
Get the number of asynchronous backups for this queue. 
- getAsyncBackupCount() - Method in class com.hazelcast.config.RingbufferConfig
- 
Gets the number of asynchronous backups. 
- getAsyncBackupCount() - Method in class com.hazelcast.config.SemaphoreConfig
- 
Returns the number of asynchronous backups. 
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.MapContainer
-  
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.BasePutOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.ClearOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EntryOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EvictOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.MapFlushOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
-  
- getAsyncBackupCount() - Method in interface com.hazelcast.spi.BackupAwareOperation
- 
The asynchronous backup count. 
- getAsyncBackupCount() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
-  
- getAsyncBackupCount() - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionOperation
-  
- getAsyncExecutor() - Method in interface com.hazelcast.client.spi.ClientExecutionService
-  
- getAsyncExecutor() - Method in class com.hazelcast.client.spi.impl.ClientExecutionServiceImpl
-  
- getAsyncExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getAsyncInternal(Data) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- getAsyncInternal(Data) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- getAsyncInternal(Data) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- getAtomicLong(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getAtomicLong(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getAtomicLong(String) - Method in interface com.hazelcast.core.HazelcastInstance
- 
Creates cluster-wide atomic long. 
- getAtomicLong(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getAtomicLong(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getAtomicLong(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getAtomicNumber() - Method in class com.hazelcast.client.console.ClientConsoleApp
-  
- getAtomicNumber() - Method in class com.hazelcast.console.ConsoleApp
-  
- getAtomicReference(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getAtomicReference(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getAtomicReference(String) - Method in interface com.hazelcast.core.HazelcastInstance
- 
Creates cluster-wide atomic reference. 
- getAtomicReference(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getAtomicReference(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getAtomicReference(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getAttribute(Node, String) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-  
- getAttribute() - Method in class com.hazelcast.config.MapIndexConfig
- 
Gets the attribute that is going to be indexed. 
- getAttribute(String) - Method in class com.hazelcast.instance.AbstractMember
-  
- getAttribute(String) - Method in class com.hazelcast.jmx.HazelcastMBean
-  
- getAttribute() - Method in class com.hazelcast.query.PredicateBuilder
-  
- getAttribute(String) - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- GetAttributeEntryProcessor - Class in com.hazelcast.web.entryprocessor
- 
Entry processor which return attributes of SessionState values 
- GetAttributeEntryProcessor(String) - Constructor for class com.hazelcast.web.entryprocessor.GetAttributeEntryProcessor
-  
- GetAttributeEntryProcessor() - Constructor for class com.hazelcast.web.entryprocessor.GetAttributeEntryProcessor
-  
- getAttributeName() - Method in interface com.hazelcast.query.impl.Index
-  
- getAttributeName() - Method in class com.hazelcast.query.impl.IndexImpl
-  
- getAttributeNames(String) - Method in class com.hazelcast.web.ClusteredSessionService
- 
Gets attribute names. 
- getAttributeNames() - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- GetAttributeNamesEntryProcessor - Class in com.hazelcast.web.entryprocessor
- 
Entry processor which return attributes keySet of SessionState values 
- GetAttributeNamesEntryProcessor() - Constructor for class com.hazelcast.web.entryprocessor.GetAttributeNamesEntryProcessor
-  
- getAttributes() - Method in class com.hazelcast.cluster.impl.JoinRequest
-  
- getAttributes() - Method in class com.hazelcast.cluster.MemberInfo
-  
- getAttributes() - Method in class com.hazelcast.config.MemberAttributeConfig
-  
- getAttributes() - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-  
- getAttributes() - Method in interface com.hazelcast.core.Member
- 
Returns configured attributes for this member.
 This method might not be available on all native clients.
 
- getAttributes() - Method in class com.hazelcast.instance.AbstractMember
-  
- getAttributes(String[]) - Method in class com.hazelcast.jmx.HazelcastMBean
-  
- getAttributes() - Method in class com.hazelcast.web.entryprocessor.SessionUpdateEntryProcessor
-  
- getAttributes() - Method in class com.hazelcast.web.SessionState
-  
- getAttributeType(String) - Method in interface com.hazelcast.query.impl.Extractable
-  
- getAttributeType(Class) - Static method in class com.hazelcast.query.impl.getters.ReflectionHelper
-  
- getAttributeType(String) - Method in class com.hazelcast.query.impl.QueryableEntry
-  
- getAttributeValue(String) - Method in interface com.hazelcast.query.impl.Extractable
-  
- getAttributeValue(String) - Method in class com.hazelcast.query.impl.QueryableEntry
-  
- getAvailable() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-  
- getAvailable() - Method in class com.hazelcast.jmx.SemaphoreMBean
-  
- getAvailableMemory() - Method in class com.hazelcast.map.impl.eviction.EvictionCheckerImpl
-  
- getAverageGetTime() - Method in interface com.hazelcast.cache.CacheStatistics
- 
The mean time to execute gets. 
- getAverageGetTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- getAverageGetTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-  
- getAverageGetTime() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-  
- getAverageGetTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
- 
Returns the mean time to execute gets on the cache. 
- getAveragePutTime() - Method in interface com.hazelcast.cache.CacheStatistics
- 
The mean time to execute puts. 
- getAveragePutTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- getAveragePutTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-  
- getAveragePutTime() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-  
- getAveragePutTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
- 
Returns the mean time to execute puts on the cache. 
- getAverageRemoveTime() - Method in interface com.hazelcast.cache.CacheStatistics
- 
The mean time to execute removes. 
- getAverageRemoveTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- getAverageRemoveTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-  
- getAverageRemoveTime() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-  
- getAverageRemoveTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
- 
Returns the mean time to execute removes on the cache. 
- getAvgAge() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- getAvgAge() - Method in interface com.hazelcast.monitor.LocalQueueStats
- 
Returns the average age of the items in this member. 
- getAwaitCount(Data, String) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- getAwaitQueueCount() - Method in class com.hazelcast.spi.impl.waitnotifyservice.impl.WaitNotifyServiceImpl
-  
- getAwsConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
- 
- getAwsConfig() - Method in class com.hazelcast.config.JoinConfig
-  
- getBackupCount() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- getBackupCount() - Method in interface com.hazelcast.concurrent.lock.LockStoreInfo
-  
- getBackupCount() - Method in class com.hazelcast.config.CacheConfig
- 
Gets the number of synchronous backups for this  ICache. 
- getBackupCount() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Gets the number of synchronous backups for this  ICache. 
- getBackupCount() - Method in class com.hazelcast.config.CollectionConfig
- 
Gets the number of synchronous backups for this collection. 
- getBackupCount() - Method in class com.hazelcast.config.MapConfig
- 
Returns the backupCount for this  IMap
- getBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
- 
Gets the number of synchronous backups for this MultiMap. 
- getBackupCount() - Method in class com.hazelcast.config.QueueConfig
- 
Get the number of synchronous backups for this queue. 
- getBackupCount() - Method in class com.hazelcast.config.RingbufferConfig
- 
Gets the number of synchronous backups. 
- getBackupCount() - Method in class com.hazelcast.config.SemaphoreConfig
- 
Returns the number of synchronous backups. 
- getBackupCount() - Method in class com.hazelcast.map.impl.MapContainer
-  
- getBackupCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getBackupCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getBackupCount() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns the number of backups per entry. 
- getBackupCount() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.NormalResponse
- 
Returns the number of synchronous backups for the operation. 
- getBackupEntryCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getBackupEntryCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getBackupEntryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns the number of backup entries hold by this member. 
- getBackupEntryMemoryCost() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getBackupEntryMemoryCost() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getBackupEntryMemoryCost() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns memory cost (number of bytes) of backup entries in this member. 
- getBackupItemCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- getBackupItemCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
- 
Returns the number of backup items in this member. 
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
-  
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
-  
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
-  
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
-  
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-  
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperation
-  
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
-  
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
-  
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
-  
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
-  
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
-  
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionClearOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionCompareAndRemoveOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.list.operations.ListAddOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.list.operations.ListRemoveOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.list.operations.ListSetOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.queue.operations.AddAllOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.queue.operations.ClearOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.queue.operations.DrainOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.queue.operations.RemoveOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollOperation
-  
- getBackupOperation() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.SetOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.lock.operations.SignalOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.InitOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
-  
- getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-  
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.BasePutOperation
-  
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
-  
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.ClearOperation
-  
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.EntryOperation
-  
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
-  
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.EvictOperation
-  
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.MapFlushOperation
-  
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.MergeOperation
-  
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-  
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-  
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperation
-  
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
-  
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-  
- getBackupOperation() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-  
- getBackupOperation() - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
-  
- getBackupOperation() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
-  
- getBackupOperation() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-  
- getBackupOperation() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-  
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.operations.ClearOperation
-  
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.operations.PutOperation
-  
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllOperation
-  
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.operations.RemoveOperation
-  
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
-  
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
-  
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
-  
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
-  
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
-  
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackOperation
-  
- getBackupOperation() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
-  
- getBackupOperation() - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
-  
- getBackupOperation() - Method in interface com.hazelcast.spi.BackupAwareOperation
- 
- getBackupOperation() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
-  
- getBackupOperation() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
-  
- getBackupOperation() - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionOperation
-  
- getBackupProcessor() - Method in class com.hazelcast.hibernate.distributed.AbstractRegionCacheEntryProcessor
-  
- getBackupProcessor() - Method in class com.hazelcast.map.AbstractEntryProcessor
-  
- getBackupProcessor() - Method in interface com.hazelcast.map.EntryProcessor
- 
Get the entry processor to be applied to backup entries. 
- getBackupProcessor() - Method in class com.hazelcast.web.entryprocessor.DeleteSessionEntryProcessor
-  
- getBackupProcessor() - Method in class com.hazelcast.web.entryprocessor.GetAttributeEntryProcessor
-  
- getBackupProcessor() - Method in class com.hazelcast.web.entryprocessor.GetAttributeNamesEntryProcessor
-  
- getBackupProcessor() - Method in class com.hazelcast.web.entryprocessor.GetSessionStateEntryProcessor
-  
- getBackupProcessor() - Method in class com.hazelcast.web.entryprocessor.SessionUpdateEntryProcessor
-  
- getBalancerIntervalSeconds() - Method in interface com.hazelcast.nio.IOService
-  
- getBalancerIntervalSeconds() - Method in class com.hazelcast.nio.NodeIOService
-  
- getBaseDir() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
- 
Base directory for all Hot Restart stores. 
- getBaseName(String) - Static method in class com.hazelcast.partition.strategy.StringPartitioningStrategy
-  
- getBatchMaxDelayMillis() - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- getBatchSize() - Method in class com.hazelcast.config.QueryCacheConfig
- 
After reaching this size, node sends buffered events to QueryCache.
 
- getBatchSize() - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- getBindAddress() - Method in interface com.hazelcast.instance.AddressPicker
- 
Returns a server socket listener address. 
- getBindings() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
-  
- getBoolean() - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- getBoolean(HazelcastProperty) - Method in class com.hazelcast.instance.HazelcastProperties
- 
- getBoolean(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
- 
Returns a field in a Json object as a boolean. 
- getBoolean(JsonObject, String, boolean) - Static method in class com.hazelcast.util.JsonUtil
- 
Returns a field in a Json object as a boolean. 
- getBooleanAttribute(String) - Method in class com.hazelcast.client.impl.MemberImpl
-  
- getBooleanAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-  
- getBooleanAttribute(String) - Method in interface com.hazelcast.core.Member
- 
Returns the value of the specified key for this member, or
 null if the value is undefined. 
- getBooleanAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-  
- getBooleanValue(String) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
-  
- getBranchQualifier() - Method in class com.hazelcast.transaction.impl.xa.SerializableXID
-  
- getBufferSize() - Method in class com.hazelcast.client.config.SocketOptions
- 
Gets the SO_SNDBUF and SO_RCVBUF options to the specified value in KB 
- getBufferSize() - Method in class com.hazelcast.config.QueryCacheConfig
- 
Returns the maximum number of events which can be stored in a buffer of partition. 
- getBuild() - Method in class com.hazelcast.instance.BuildInfo
-  
- getBuild() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getBuildInfo() - Static method in class com.hazelcast.instance.BuildInfoProvider
-  
- getBuildInfo() - Method in class com.hazelcast.instance.Node
-  
- getBuildNumber() - Method in class com.hazelcast.cluster.impl.JoinMessage
-  
- getBuildNumber() - Method in class com.hazelcast.instance.BuildInfo
-  
- getBuiltinDefinitions() - Method in class com.hazelcast.cache.impl.CachePortableHook
-  
- getBuiltinDefinitions() - Method in class com.hazelcast.client.impl.client.ClientPortableHook
-  
- getBuiltinDefinitions() - Method in class com.hazelcast.collection.impl.collection.CollectionPortableHook
-  
- getBuiltinDefinitions() - Method in class com.hazelcast.collection.impl.queue.QueuePortableHook
-  
- getBuiltinDefinitions() - Method in class com.hazelcast.concurrent.atomiclong.client.AtomicLongPortableHook
-  
- getBuiltinDefinitions() - Method in class com.hazelcast.concurrent.atomicreference.client.AtomicReferencePortableHook
-  
- getBuiltinDefinitions() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownLatchPortableHook
-  
- getBuiltinDefinitions() - Method in class com.hazelcast.concurrent.lock.client.LockPortableHook
-  
- getBuiltinDefinitions() - Method in class com.hazelcast.concurrent.semaphore.client.SemaphorePortableHook
-  
- getBuiltinDefinitions() - Method in class com.hazelcast.executor.impl.ExecutorPortableHook
-  
- getBuiltinDefinitions() - Method in interface com.hazelcast.internal.serialization.PortableHook
-  
- getBuiltinDefinitions() - Method in class com.hazelcast.map.impl.MapPortableHook
-  
- getBuiltinDefinitions() - Method in class com.hazelcast.mapreduce.impl.MapReducePortableHook
-  
- getBuiltinDefinitions() - Method in class com.hazelcast.multimap.impl.MultiMapPortableHook
-  
- getBuiltinDefinitions() - Method in class com.hazelcast.partition.PartitionPortableHook
-  
- getBuiltinDefinitions() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-  
- getBuiltinDefinitions() - Method in class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
-  
- getBuiltinDefinitions() - Method in class com.hazelcast.spi.impl.SpiPortableHook
-  
- getBuiltinDefinitions() - Method in class com.hazelcast.topic.impl.TopicPortableHook
-  
- getBuiltinDefinitions() - Method in class com.hazelcast.transaction.client.ClientTxnPortableHook
-  
- getBulkLoad() - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
-  
- getById(int) - Static method in enum com.hazelcast.client.impl.protocol.AuthenticationStatus
-  
- getById(int) - Static method in enum com.hazelcast.config.WanAcknowledgeType
- 
- getById(int) - Static method in enum com.hazelcast.ringbuffer.OverflowPolicy
- 
Returns the OverflowPolicy for the given id. 
- getById(byte) - Static method in enum com.hazelcast.util.IterationType
- 
Returns the IterationType for the given id. 
- getByte(int) - Method in interface com.hazelcast.client.impl.protocol.util.ClientProtocolBuffer
- 
Get the value at a given index. 
- getByte() - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- getByte(int) - Method in class com.hazelcast.client.impl.protocol.util.SafeBuffer
-  
- getByte(int) - Method in class com.hazelcast.client.impl.protocol.util.UnsafeBuffer
-  
- getByteArray() - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- getByteArray(String, String) - Method in interface com.hazelcast.internal.ascii.TextCommandService
-  
- getByteArray(String, String) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- getByteAttribute(String) - Method in class com.hazelcast.client.impl.MemberImpl
-  
- getByteAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-  
- getByteAttribute(String) - Method in interface com.hazelcast.core.Member
- 
Returns the value of the specified key for this member or
 null if the value is undefined. 
- getByteAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-  
- getByteOrder() - Method in class com.hazelcast.config.SerializationConfig
- 
Note that result of useNativeByteOrder is not reflected to return value of this method. 
- getByteOrder() - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- getByteOrder() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- getByteOrder() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataOutputStream
-  
- getByteOrder() - Method in interface com.hazelcast.internal.serialization.InputOutputFactory
-  
- getByteOrder() - Method in interface com.hazelcast.internal.serialization.PortableContext
-  
- getByteOrder() - Method in interface com.hazelcast.internal.serialization.SerializationService
-  
- getByteOrder() - Method in interface com.hazelcast.nio.ObjectDataInput
-  
- getByteOrder() - Method in interface com.hazelcast.nio.ObjectDataOutput
-  
- getBytes(int, byte[]) - Method in interface com.hazelcast.client.impl.protocol.util.ClientProtocolBuffer
- 
Get from the underlying buffer into a supplied byte array. 
- getBytes(int, byte[], int, int) - Method in interface com.hazelcast.client.impl.protocol.util.ClientProtocolBuffer
- 
Get bytes from the underlying buffer into a supplied byte array. 
- getBytes(int, byte[]) - Method in class com.hazelcast.client.impl.protocol.util.SafeBuffer
-  
- getBytes(int, byte[], int, int) - Method in class com.hazelcast.client.impl.protocol.util.SafeBuffer
-  
- getBytes(int, byte[]) - Method in class com.hazelcast.client.impl.protocol.util.UnsafeBuffer
-  
- getBytes(int, byte[], int, int) - Method in class com.hazelcast.client.impl.protocol.util.UnsafeBuffer
-  
- getBytes() - Method in class com.hazelcast.internal.ascii.memcache.MemcacheEntry
-  
- getBytes() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- getByType(int) - Static method in enum com.hazelcast.cache.impl.CacheEventType
-  
- getByType(int) - Static method in enum com.hazelcast.core.EntryEventType
- 
Returns the EntryEventType as an enum. 
- getByType(int) - Static method in enum com.hazelcast.core.ItemEventType
-  
- getByType(int) - Static method in enum com.hazelcast.map.impl.client.AbstractTxnMapRequest.TxnMapRequestType
-  
- getByValue(int) - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
-  
- getCache(String, Class<K>, Class<V>) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- getCache(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- getCache() - Method in class com.hazelcast.hibernate.region.AbstractTransactionalDataRegion
-  
- getCache() - Method in interface com.hazelcast.hibernate.region.HazelcastRegion
-  
- getCache(String) - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
-  
- getCacheConfig(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- getCacheConfig(String) - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- getCacheConfig(String) - Method in class com.hazelcast.config.Config
-  
- getCacheConfigFromPartition(String, String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- getCacheConfigFromPartition(String, String) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-  
- getCacheConfigFromPartition(String, String) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
-  
- getCacheConfigLocal(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- getCacheConfigLocal(String) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-  
- getCacheConfigLocal(String) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
-  
- getCacheConfigs() - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- getCacheConfigs() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-  
- getCacheConfigs() - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- getCacheConfigs() - Method in class com.hazelcast.config.Config
-  
- getCacheContext(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- getCacheDataDescription() - Method in class com.hazelcast.hibernate.region.AbstractTransactionalDataRegion
-  
- getCacheDeserializedValues() - Method in class com.hazelcast.config.MapConfig
- 
Get current value cache settings 
- getCachedValue(Data) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- getCachedValue(List<Data>, List<Object>) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- getCachedValue(Record) - Static method in class com.hazelcast.map.impl.record.Records
- 
Get current cached value from the record. 
- getCachedValueUnsafe() - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- getCachedValueUnsafe() - Method in interface com.hazelcast.map.impl.record.Record
- 
Get current cache value or null. 
- getCacheEntryEventFilterFactory() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-  
- getCacheEntryListener() - Method in interface com.hazelcast.cache.impl.CacheEntryListenerProvider
- 
Gets wrapped CacheEntryListener
 
- getCacheEntryListener() - Method in class com.hazelcast.cache.impl.CacheEventListenerAdaptor
-  
- getCacheEntryListenerConfigurations() - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- getCacheEntryListenerCount() - Method in class com.hazelcast.cache.impl.CacheContext
-  
- getCacheEntryListenerFactory() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-  
- getCacheEntryListeners() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
- getCacheEntryListeners() - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- getCacheEventType() - Method in interface com.hazelcast.cache.impl.CacheEventData
- 
Gets cache event type of this event data. 
- getCacheEventType() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-  
- getCacheEvictions() - Method in interface com.hazelcast.cache.CacheStatistics
- 
The total number of evictions from the cache. 
- getCacheEvictions() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- getCacheEvictions() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-  
- getCacheEvictions() - Method in class com.hazelcast.client.cache.impl.ClientCacheStatisticsImpl
-  
- getCacheEvictions() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-  
- getCacheEvictions() - Method in interface com.hazelcast.monitor.LocalCacheStats
- 
Returns the number of evictions on the cache. 
- getCacheExpiries() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
- 
The total number of expiries from the cache. 
- getCacheExpiries() - Method in class com.hazelcast.client.cache.impl.ClientCacheStatisticsImpl
-  
- getCacheGets() - Method in interface com.hazelcast.cache.CacheStatistics
- 
The total number of requests to the cache. 
- getCacheGets() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- getCacheGets() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-  
- getCacheGets() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-  
- getCacheGets() - Method in interface com.hazelcast.monitor.LocalCacheStats
- 
Returns the number of gets on the cache. 
- getCacheGetTimeTakenNanos() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- getCacheHitPercentage() - Method in interface com.hazelcast.cache.CacheStatistics
- 
This is a measure of cache efficiency. 
- getCacheHitPercentage() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- getCacheHitPercentage() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-  
- getCacheHitPercentage() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-  
- getCacheHitPercentage() - Method in interface com.hazelcast.monitor.LocalCacheStats
- 
Returns the percentage of hits (successful get operations) on the cache. 
- getCacheHits() - Method in interface com.hazelcast.cache.CacheStatistics
- 
The number of get requests that were satisfied by the cache. 
- getCacheHits() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- getCacheHits() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-  
- getCacheHits() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-  
- getCacheHits() - Method in interface com.hazelcast.monitor.LocalCacheStats
- 
Returns the number of hits (successful get operations) on the cache. 
- getCacheLoaderFactory() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Gets the factory for the CacheLoader.
 
- getCacheManager(URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.HazelcastCachingProvider
-  
- getCacheManager(URI, ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
-  
- getCacheManager() - Method in class com.hazelcast.cache.HazelcastCachingProvider
-  
- getCacheManager(URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-  
- getCacheManager(URI, ClassLoader) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-  
- getCacheManager() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-  
- getCacheManager() - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- getCacheManager() - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- getCacheManager(HazelcastInstance, String, Properties) - Static method in class com.hazelcast.spring.cache.SpringHazelcastCachingProvider
- 
Creates a CacheManageron an existing HazelcastInstance.
 
- getCacheManager(String, Properties) - Static method in class com.hazelcast.spring.cache.SpringHazelcastCachingProvider
-  
- getCacheMisses() - Method in interface com.hazelcast.cache.CacheStatistics
- 
A miss is a get request that is not satisfied. 
- getCacheMisses() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- getCacheMisses() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-  
- getCacheMisses() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-  
- getCacheMisses() - Method in interface com.hazelcast.monitor.LocalCacheStats
- 
Returns the number of missed cache accesses on the cache. 
- getCacheMissPercentage() - Method in interface com.hazelcast.cache.CacheStatistics
- 
Returns the percentage of cache accesses that did not find a requested entry
 in the cache. 
- getCacheMissPercentage() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- getCacheMissPercentage() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-  
- getCacheMissPercentage() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-  
- getCacheMissPercentage() - Method in interface com.hazelcast.monitor.LocalCacheStats
- 
Returns the percentage of missed cache accesses on the cache. 
- getCacheName() - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- getCacheNames() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- getCacheNames() - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
-  
- getCacheNameWithPrefix(String) - Method in interface com.hazelcast.cache.HazelcastCacheManager
- 
Gets cache name by adding manager prefix. 
- getCacheNameWithPrefix(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- getCacheOperationProvider(String, InMemoryFormat) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- getCacheOperationProvider(String, InMemoryFormat) - Method in interface com.hazelcast.cache.impl.ICacheService
- 
Creates cache operations according to the storage-type of the cache 
- getCachePuts() - Method in interface com.hazelcast.cache.CacheStatistics
- 
The total number of puts to the cache. 
- getCachePuts() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- getCachePuts() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-  
- getCachePuts() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-  
- getCachePuts() - Method in interface com.hazelcast.monitor.LocalCacheStats
- 
Returns the number of puts to the queue. 
- getCachePutTimeTakenNanos() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- getCacheRemovals() - Method in interface com.hazelcast.cache.CacheStatistics
- 
The total number of removals from the cache. 
- getCacheRemovals() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- getCacheRemovals() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-  
- getCacheRemovals() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-  
- getCacheRemovals() - Method in interface com.hazelcast.monitor.LocalCacheStats
- 
Returns the number of removals from the queue. 
- getCacheRemoveTimeTakenNanos() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- getCacheService() - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-  
- getCacheStats() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- getCacheStats() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Gets the Cache statistics associated with this  CacheService. 
- getCacheTimeTakenNanos - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- getCacheUnchecked(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- getCacheWanEventPublisher() - Method in class com.hazelcast.cache.impl.CacheService
-  
- getCacheWanEventPublisher() - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- getCacheWriterFactory() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Gets the factory for the CacheWriter.
 
- getCachingProvider() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- getCallback() - Method in class com.hazelcast.spi.InvocationBuilder
- 
Deprecated. 
- getCaller() - Method in class com.hazelcast.collection.impl.collection.CollectionEvent
-  
- getCaller() - Method in interface com.hazelcast.map.impl.event.EventData
-  
- getCaller() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- getCallerAddress() - Method in class com.hazelcast.spi.Operation
-  
- getCallerUuid() - Method in class com.hazelcast.spi.Operation
-  
- getCallerUuid() - Method in class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
-  
- getCallId() - Method in class com.hazelcast.client.impl.client.ClientRequest
-  
- getCallId() - Method in class com.hazelcast.client.impl.client.ClientResponse
-  
- getCallId() - Method in class com.hazelcast.client.spi.impl.listener.ClientEventRegistration
- 
Call id of first event registration request 
- getCallId() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
- 
Returns the call id of the operation this response belongs to. 
- getCallId() - Method in class com.hazelcast.spi.Operation
- 
Gets the callId of this Operation. 
- getCallTimeout() - Method in class com.hazelcast.spi.InvocationBuilder
-  
- getCallTimeout() - Method in class com.hazelcast.spi.Operation
- 
Gets the call timeout in milliseconds. 
- getCancelledTaskCount() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-  
- getCancelledTaskCount() - Method in interface com.hazelcast.monitor.LocalExecutorStats
- 
Returns the number of cancelled operations on the executor service. 
- getCanonicalHeaders() - Method in class com.hazelcast.aws.security.EC2RequestSigner
-  
- getCanonicalizedQueryString(Map<String, String>) - Method in class com.hazelcast.aws.security.EC2RequestSigner
-  
- getCanonicalizedQueryString(List<String>) - Method in class com.hazelcast.aws.security.EC2RequestSigner
-  
- getCapacity() - Method in class com.hazelcast.config.RingbufferConfig
- 
Gets the capacity of the ringbuffer. 
- getCapacity() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-  
- getCause() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.ErrorResponse
-  
- getChunk() - Method in class com.hazelcast.mapreduce.impl.notification.IntermediateChunkNotification
-  
- getChunk() - Method in class com.hazelcast.mapreduce.impl.notification.LastChunkNotification
-  
- getChunkSize() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.AbstractMapReduceTask
-  
- getChunkSize() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForCustomMessageTask
-  
- getChunkSize() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForListMessageTask
-  
- getChunkSize() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMapMessageTask
-  
- getChunkSize() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMultiMapMessageTask
-  
- getChunkSize() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForSetMessageTask
-  
- getChunkSize() - Method in class com.hazelcast.config.JobTrackerConfig
- 
Gets the number of emitted values before a chunk is send to the reducers. 
- getChunkSize() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-  
- getChunkSize() - Method in class com.hazelcast.mapreduce.impl.task.MapCombineTask
-  
- getClassDefinitions() - Method in class com.hazelcast.config.SerializationConfig
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheAddInvalidationListenerRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheAddPartitionLostListenerRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheBatchInvalidationMessage
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheClearRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheContainsKeyRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheCreateConfigRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheDestroyRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheEntryProcessorRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheGetAllRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheGetAndRemoveRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheGetAndReplaceRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheGetConfigRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheGetRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheIterateRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheManagementConfigRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CachePutAllRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CachePutIfAbsentRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CachePutRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheRemoveEntryListenerRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheRemoveInvalidationListenerRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheRemovePartitionLostListenerRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheRemoveRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheReplaceRequest
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheSingleInvalidationMessage
-  
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheSizeRequest
-  
- getClassId() - Method in class com.hazelcast.client.impl.client.AddDistributedObjectListenerRequest
-  
- getClassId() - Method in class com.hazelcast.client.impl.client.AuthenticationRequest
-  
- getClassId() - Method in class com.hazelcast.client.impl.client.ClientCreateRequest
-  
- getClassId() - Method in class com.hazelcast.client.impl.client.ClientDestroyRequest
-  
- getClassId() - Method in class com.hazelcast.client.impl.client.ClientPrincipal
-  
- getClassId() - Method in class com.hazelcast.client.impl.client.DistributedObjectInfo
-  
- getClassId() - Method in class com.hazelcast.client.impl.client.GenericError
-  
- getClassId() - Method in class com.hazelcast.client.impl.client.GetDistributedObjectsRequest
-  
- getClassId() - Method in class com.hazelcast.client.impl.client.GetMemberListRequest
-  
- getClassId() - Method in class com.hazelcast.client.impl.client.RemoveAllListeners
-  
- getClassId() - Method in class com.hazelcast.client.impl.client.RemoveDistributedObjectListenerRequest
-  
- getClassId() - Method in class com.hazelcast.cluster.client.AddMembershipListenerRequest
-  
- getClassId() - Method in class com.hazelcast.cluster.client.ClientPingRequest
-  
- getClassId() - Method in class com.hazelcast.cluster.client.RegisterMembershipListenerRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.collection.client.CollectionAddAllRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.collection.client.CollectionAddListenerRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.collection.client.CollectionAddRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.collection.client.CollectionClearRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.collection.client.CollectionCompareAndRemoveRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.collection.client.CollectionContainsRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.collection.client.CollectionGetAllRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.collection.client.CollectionIsEmptyRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.collection.client.CollectionRemoveListenerRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.collection.client.CollectionRemoveRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.collection.client.CollectionSizeRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.list.client.ListAddAllRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.list.client.ListAddRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.list.client.ListGetRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.list.client.ListIndexOfRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.list.client.ListRemoveRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.list.client.ListSetRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.list.client.ListSubRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.queue.client.AddAllRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.queue.client.AddListenerRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.queue.client.ClearRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.queue.client.CompareAndRemoveRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.queue.client.ContainsRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.queue.client.DrainRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.queue.client.IsEmptyRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.queue.client.IteratorRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.queue.client.OfferRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.queue.client.PeekRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.queue.client.PollRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.queue.client.RemainingCapacityRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.queue.client.RemoveListenerRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.queue.client.RemoveRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.queue.client.SizeRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.txnlist.client.TxnListAddRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.txnlist.client.TxnListRemoveRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.txnlist.client.TxnListSizeRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnOfferRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnPeekRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnPollRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnSizeRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.txnset.client.TxnSetAddRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.txnset.client.TxnSetRemoveRequest
-  
- getClassId() - Method in class com.hazelcast.collection.impl.txnset.client.TxnSetSizeRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.atomiclong.client.AddAndGetRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.atomiclong.client.AlterAndGetRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.atomiclong.client.AlterRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.atomiclong.client.ApplyRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.atomiclong.client.CompareAndSetRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.atomiclong.client.GetAndAddRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.atomiclong.client.GetAndAlterRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.atomiclong.client.GetAndSetRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.atomiclong.client.SetRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.atomicreference.client.AlterAndGetRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.atomicreference.client.AlterRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.atomicreference.client.ApplyRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.atomicreference.client.CompareAndSetRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.atomicreference.client.ContainsRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.atomicreference.client.GetAndAlterRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.atomicreference.client.GetAndSetRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.atomicreference.client.GetRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.atomicreference.client.IsNullRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.atomicreference.client.SetRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.lock.client.AwaitRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.lock.client.BeforeAwaitRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.lock.client.IsLockedRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.lock.client.LockRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.lock.client.SignalRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.lock.client.UnlockRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.semaphore.client.AcquireRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.semaphore.client.AvailableRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.semaphore.client.DrainRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.semaphore.client.InitRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.semaphore.client.ReduceRequest
-  
- getClassId() - Method in class com.hazelcast.concurrent.semaphore.client.ReleaseRequest
-  
- getClassId() - Method in class com.hazelcast.executor.impl.client.CancellationRequest
-  
- getClassId() - Method in class com.hazelcast.executor.impl.client.IsShutdownRequest
-  
- getClassId() - Method in class com.hazelcast.executor.impl.client.PartitionTargetCallableRequest
-  
- getClassId() - Method in class com.hazelcast.executor.impl.client.ShutdownRequest
-  
- getClassId() - Method in class com.hazelcast.executor.impl.client.SpecificTargetCallableRequest
-  
- getClassId() - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-  
- getClassId() - Method in class com.hazelcast.internal.serialization.impl.FieldDefinitionImpl
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapAddEntryListenerRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapAddEntryListenerSqlRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapAddIndexRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapAddNearCacheEntryListenerRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapAddPartitionLostListenerRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapClearNearCacheRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapClearRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapContainsKeyRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapContainsValueRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapDeleteRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapEvictAllRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapEvictRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapFlushRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapGetAllRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapGetRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapIsEmptyRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapIsLockedRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapLockRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapPutAllRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapPutIfAbsentRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapPutRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapPutTransientRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapQueryRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapRemoveEntryListenerRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapRemovePartitionLostListenerRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapReplaceIfSameRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapReplaceRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapSetRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapSizeRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapSQLQueryRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapTryPutRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.MapUnlockRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.TxnMapRequest
-  
- getClassId() - Method in class com.hazelcast.map.impl.client.TxnMapRequestWithSQLQuery
-  
- getClassId() - Method in class com.hazelcast.mapreduce.impl.client.ClientCancellationRequest
-  
- getClassId() - Method in class com.hazelcast.mapreduce.impl.client.ClientJobProcessInformationRequest
-  
- getClassId() - Method in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-  
- getClassId() - Method in class com.hazelcast.mapreduce.impl.task.TransferableJobProcessInformation
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.ClearRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.ContainsRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.CountRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.EntrySetRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.GetAllRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.KeyBasedContainsRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.KeySetRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.MultiMapIsLockedRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.MultiMapLockRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.MultiMapUnlockRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.PortableEntrySetResponse
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.PutRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.RemoveAllRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.RemoveEntryListenerRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.RemoveRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.SizeRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapGetRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapPutRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveAllRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapSizeRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapValueCountRequest
-  
- getClassId() - Method in class com.hazelcast.multimap.impl.client.ValuesRequest
-  
- getClassId() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
- 
Returns the class id. 
- getClassId() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- getClassId() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
-  
- getClassId() - Method in interface com.hazelcast.nio.serialization.Portable
- 
Returns class identifier for this portable class. 
- getClassId() - Method in class com.hazelcast.partition.client.AddPartitionLostListenerRequest
-  
- getClassId() - Method in class com.hazelcast.partition.client.GetPartitionsRequest
-  
- getClassId() - Method in class com.hazelcast.partition.client.RemovePartitionLostListenerRequest
-  
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
-  
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddNearCacheListenerRequest
-  
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapClearRequest
-  
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsKeyRequest
-  
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsValueRequest
-  
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapEntrySetRequest
-  
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapGetRequest
-  
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapIsEmptyRequest
-  
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapKeySetRequest
-  
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-  
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutTtlRequest
-  
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-  
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveRequest
-  
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapSizeRequest
-  
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapValuesRequest
-  
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
-  
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeys
-  
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-  
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapValueCollection
-  
- getClassId() - Method in class com.hazelcast.ringbuffer.impl.client.AddAllRequest
-  
- getClassId() - Method in class com.hazelcast.ringbuffer.impl.client.AddRequest
-  
- getClassId() - Method in class com.hazelcast.ringbuffer.impl.client.CapacityRequest
-  
- getClassId() - Method in class com.hazelcast.ringbuffer.impl.client.HeadSequenceRequest
-  
- getClassId() - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
-  
- getClassId() - Method in class com.hazelcast.ringbuffer.impl.client.ReadManyRequest
-  
- getClassId() - Method in class com.hazelcast.ringbuffer.impl.client.ReadOneRequest
-  
- getClassId() - Method in class com.hazelcast.ringbuffer.impl.client.RemainingCapacityRequest
-  
- getClassId() - Method in class com.hazelcast.ringbuffer.impl.client.SizeRequest
-  
- getClassId() - Method in class com.hazelcast.ringbuffer.impl.client.TailSequenceRequest
-  
- getClassId() - Method in class com.hazelcast.security.UsernamePasswordCredentials
-  
- getClassId() - Method in class com.hazelcast.spi.impl.PortableCachePartitionLostEvent
-  
- getClassId() - Method in class com.hazelcast.spi.impl.PortableCollection
-  
- getClassId() - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
-  
- getClassId() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-  
- getClassId() - Method in class com.hazelcast.spi.impl.PortableItemEvent
-  
- getClassId() - Method in class com.hazelcast.spi.impl.PortableMapPartitionLostEvent
-  
- getClassId() - Method in class com.hazelcast.spi.impl.PortablePartitionLostEvent
-  
- getClassId() - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-  
- getClassId() - Method in class com.hazelcast.topic.impl.client.PortableMessage
-  
- getClassId() - Method in class com.hazelcast.topic.impl.client.PublishRequest
-  
- getClassId() - Method in class com.hazelcast.topic.impl.client.RemoveMessageListenerRequest
-  
- getClassId() - Method in class com.hazelcast.transaction.client.ClearRemoteTransactionRequest
-  
- getClassId() - Method in class com.hazelcast.transaction.client.CollectXATransactionsRequest
-  
- getClassId() - Method in class com.hazelcast.transaction.client.CommitTransactionRequest
-  
- getClassId() - Method in class com.hazelcast.transaction.client.CommitXATransactionRequest
-  
- getClassId() - Method in class com.hazelcast.transaction.client.CreateTransactionRequest
-  
- getClassId() - Method in class com.hazelcast.transaction.client.CreateXATransactionRequest
-  
- getClassId() - Method in class com.hazelcast.transaction.client.FinalizeXATransactionRequest
-  
- getClassId() - Method in class com.hazelcast.transaction.client.PrepareXATransactionRequest
-  
- getClassId() - Method in class com.hazelcast.transaction.client.RollbackTransactionRequest
-  
- getClassId() - Method in class com.hazelcast.transaction.client.RollbackXATransactionRequest
-  
- getClassLoader() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- getClassLoader() - Method in class com.hazelcast.client.config.ClientConfig
- 
Gets the classLoader 
- getClassLoader() - Method in class com.hazelcast.config.Config
- 
Returns the class-loader that will be used in serialization. 
- getClassLoader() - Method in class com.hazelcast.instance.HazelcastThreadGroup
- 
Returns the ClassLoader used by threads of this HazelcastThreadGroup. 
- getClassLoader() - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- getClassLoader() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- getClassLoader() - Method in interface com.hazelcast.internal.serialization.SerializationService
-  
- getClassLoader() - Method in interface com.hazelcast.nio.ObjectDataInput
- 
Returns class loader that internally used for objects 
- getClassName() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
-  
- getClassName() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
-  
- getClassName() - Method in class com.hazelcast.config.CredentialsFactoryConfig
-  
- getClassName() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
-  
- getClassName() - Method in class com.hazelcast.config.GlobalSerializerConfig
-  
- getClassName() - Method in class com.hazelcast.config.ListenerConfig
- 
Returns the name of the class of the EventListener. 
- getClassName() - Method in class com.hazelcast.config.LoginModuleConfig
-  
- getClassName() - Method in class com.hazelcast.config.MapStoreConfig
- 
Returns the name of the MapStore implementation class 
- getClassName() - Method in class com.hazelcast.config.PermissionPolicyConfig
-  
- getClassName() - Method in class com.hazelcast.config.PredicateConfig
- 
Returns the name of the class of the Predicate. 
- getClassName() - Method in class com.hazelcast.config.QueueStoreConfig
-  
- getClassName() - Method in class com.hazelcast.config.SecurityInterceptorConfig
-  
- getClassName() - Method in class com.hazelcast.config.SerializerConfig
- 
Returns the class name of the serializer implementation. 
- getClassName() - Method in class com.hazelcast.config.ServiceConfig
-  
- getClassName() - Method in class com.hazelcast.config.SocketInterceptorConfig
- 
- getClassVersion() - Method in class com.hazelcast.client.impl.client.ClientRequest
- 
Version for internal requests. 
- getClassVersion(int, int) - Method in interface com.hazelcast.internal.serialization.PortableContext
-  
- getClassVersion() - Method in interface com.hazelcast.nio.serialization.VersionedPortable
- 
Returns version for this Portable class 
- getClient() - Method in class com.hazelcast.client.proxy.txn.TransactionContextProxy
-  
- getClient() - Method in class com.hazelcast.client.proxy.txn.xa.XATransactionContextProxy
-  
- getClient() - Method in class com.hazelcast.client.spi.ClientProxy
-  
- getClient() - Method in interface com.hazelcast.client.spi.ClientTransactionContext
-  
- getClient() - Method in class com.hazelcast.client.spi.impl.ClientTransactionManagerServiceImpl
-  
- getClient() - Method in class com.hazelcast.client.txn.proxy.xa.XATransactionContextProxy
-  
- getClient() - Method in class com.hazelcast.client.txn.TransactionContextProxy
-  
- getClientClusterService() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getClientConfig() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getClientConfig() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getClientConfig() - Method in class com.hazelcast.client.spi.ClientContext
-  
- getClientContext() - Method in class com.hazelcast.client.cache.impl.ClientCacheDistributedObject
-  
- getClientEndpointCount() - Method in interface com.hazelcast.client.ClientEngine
-  
- getClientEndpointCount() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- getClientEndpointCount() - Method in class com.hazelcast.jmx.ClientEngineMBean
-  
- getClientEngine() - Method in class com.hazelcast.client.impl.client.ClientRequest
-  
- getClientEngineMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getClientExceptionFactory() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- getClientExecutionService() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getClientExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getClientExtension() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getClientLoginModuleConfigs() - Method in class com.hazelcast.config.SecurityConfig
-  
- getClientMessage() - Method in class com.hazelcast.client.spi.impl.ClientInvocation
-  
- getClientPartitionService() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getClientPermissionConfigs() - Method in class com.hazelcast.config.SecurityConfig
-  
- getClientPolicyConfig() - Method in class com.hazelcast.config.SecurityConfig
-  
- getClientProperties() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getClients() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- getClients() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- getClients() - Method in interface com.hazelcast.monitor.MemberState
-  
- getClientService() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getClientService() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getClientService() - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the client service of this Hazelcast instance. 
- getClientService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getClientService() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getClientService() - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.AbstractTransactionalMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCommitMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCreateMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionRollbackMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListAddMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListRemoveMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListSizeMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapContainsKeyMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapDeleteMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetForUpdateMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapIsEmptyMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetWithPredicateMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutIfAbsentMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveIfSameMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceIfSameMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSetMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSizeMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesWithPredicateMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapGetMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapPutMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveEntryMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapSizeMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapValueCountMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueOfferMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePeekMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePollMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueSizeMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueTakeMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetAddMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetRemoveMessageTask
-  
- getClientThreadId() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetSizeMessageTask
-  
- getClientType() - Method in class com.hazelcast.client.ClientEvent
-  
- getClientType() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- getClientType() - Method in class com.hazelcast.client.impl.ClientImpl
-  
- getClientType() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
-  
- getClientType() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationCustomCredentialsMessageTask
-  
- getClientType() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationMessageTask
-  
- getClientType() - Method in interface com.hazelcast.core.Client
- 
Returns the type of this client. 
- getClosedTime() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- getCluster() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getCluster() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getCluster() - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the Cluster that this Hazelcast instance is part of. 
- getCluster() - Method in class com.hazelcast.core.InitialMembershipEvent
- 
Returns the cluster of the event. 
- getCluster() - Method in class com.hazelcast.core.MembershipEvent
- 
Returns the cluster of the event. 
- getCluster() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getCluster() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getCluster() - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getClusterClock() - Method in interface com.hazelcast.cluster.ClusterService
- 
- getClusterClock() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- getClusteredSessionService() - Method in class com.hazelcast.web.WebFilter
-  
- getClusterHeartbeatManager() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- getClusterId() - Method in interface com.hazelcast.cluster.ClusterService
- 
Returns UUID for the cluster. 
- getClusterId() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- getClusterJoinManager() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- getClusterName() - Method in class com.hazelcast.internal.management.ManagementCenterIdentifier
-  
- getClusterName() - Method in class com.hazelcast.monitor.TimedMemberState
-  
- getClusterService() - Method in interface com.hazelcast.client.ClientEngine
-  
- getClusterService() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- getClusterService() - Method in class com.hazelcast.client.spi.ClientContext
-  
- getClusterService() - Method in class com.hazelcast.instance.Node
-  
- getClusterService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getClusterService() - Method in interface com.hazelcast.spi.NodeEngine
- 
Gets the ClusterService. 
- getClusterStartTime() - Method in class com.hazelcast.cluster.impl.ClusterClockImpl
-  
- getClusterState() - Method in class com.hazelcast.client.proxy.ClientClusterProxy
-  
- getClusterState() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- getClusterState() - Method in interface com.hazelcast.core.Cluster
- 
Returns the state of the cluster. 
- getClusterStateManager() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- GetClusterStateRequest - Class in com.hazelcast.internal.management.request
- 
Request coming from Management Center for getting the  ClusterState
- GetClusterStateRequest() - Constructor for class com.hazelcast.internal.management.request.GetClusterStateRequest
-  
- getClusterTime() - Method in class com.hazelcast.client.proxy.ClientClusterProxy
-  
- getClusterTime() - Method in interface com.hazelcast.client.spi.ClientClusterService
- 
Returns the cluster-time. 
- getClusterTime() - Method in class com.hazelcast.client.spi.impl.ClientClusterServiceImpl
-  
- getClusterTime() - Method in interface com.hazelcast.cluster.ClusterClock
- 
Returns the cluster-time in milliseconds. 
- getClusterTime() - Method in class com.hazelcast.cluster.impl.ClusterClockImpl
-  
- getClusterTime() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- getClusterTime() - Method in interface com.hazelcast.core.Cluster
- 
Returns the cluster-wide time in milliseconds. 
- getClusterTime() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getClusterUpTime() - Method in interface com.hazelcast.cluster.ClusterClock
- 
Returns the cluster  up-time in milliseconds. 
- getClusterUpTime() - Method in class com.hazelcast.cluster.impl.ClusterClockImpl
-  
- getCmdGet() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- getCmdSet() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- getCmdTouch() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- getCodec() - Method in class com.hazelcast.client.spi.impl.listener.ClientEventRegistration
-  
- getCodec() - Method in class com.hazelcast.client.spi.impl.listener.ClientRegistrationKey
-  
- getCollator() - Method in interface com.hazelcast.mapreduce.aggregation.Aggregation
- 
Returns the Collator implementation used in this aggregation. 
- getCollator() - Method in interface com.hazelcast.mapreduce.aggregation.impl.AggType
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalAvgAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMaxAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMinAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalSumAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerAvgAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMaxAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMinAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerSumAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.ComparableMaxAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.ComparableMinAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.CountAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.DistinctValuesAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleAvgAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleMaxAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleMinAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleSumAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerAvgAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerMaxAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerMinAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerSumAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongAvgAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongMaxAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongMinAggregation
-  
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongSumAggregation
-  
- getCollected() - Method in class com.hazelcast.mapreduce.impl.task.DefaultContext
-  
- getCollection() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- getCollection() - Method in class com.hazelcast.collection.impl.list.ListContainer
-  
- getCollection() - Method in class com.hazelcast.collection.impl.set.SetContainer
-  
- getCollection() - Method in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
-  
- getCollection() - Method in class com.hazelcast.collection.impl.txnlist.TransactionalListProxy
-  
- getCollection() - Method in class com.hazelcast.collection.impl.txnset.TransactionalSetProxy
-  
- getCollection(boolean) - Method in class com.hazelcast.multimap.impl.MultiMapValue
-  
- getCollection() - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
-  
- getCollection() - Method in class com.hazelcast.spi.impl.PortableCollection
-  
- getCollection() - Method in class com.hazelcast.spi.impl.SerializableList
-  
- getCollectionContainer(String) - Method in class com.hazelcast.multimap.impl.MultiMapPartitionContainer
-  
- getCombinerFactory() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.AbstractMapReduceTask
-  
- getCombinerFactory() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForCustomMessageTask
-  
- getCombinerFactory() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForListMessageTask
-  
- getCombinerFactory() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMapMessageTask
-  
- getCombinerFactory() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMultiMapMessageTask
-  
- getCombinerFactory() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForSetMessageTask
-  
- getCombinerFactory() - Method in interface com.hazelcast.mapreduce.aggregation.Aggregation
- 
Returns the CombinerFactory for this aggregation to pre-reduce values on mapping
 nodes. 
- getCombinerFactory() - Method in interface com.hazelcast.mapreduce.aggregation.impl.AggType
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalAvgAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMaxAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMinAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalSumAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerAvgAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMaxAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMinAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerSumAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.ComparableMaxAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.ComparableMinAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.CountAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DistinctValuesAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleAvgAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleMaxAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleMinAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleSumAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerAvgAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerMaxAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerMinAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerSumAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongAvgAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongMaxAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongMinAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongSumAggregation
-  
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-  
- GetCommand - Class in com.hazelcast.internal.ascii.memcache
-  
- GetCommand(TextCommandConstants.TextCommandType, String) - Constructor for class com.hazelcast.internal.ascii.memcache.GetCommand
-  
- GetCommand(String) - Constructor for class com.hazelcast.internal.ascii.memcache.GetCommand
-  
- getCommandHandler() - Method in class com.hazelcast.internal.management.ManagementCenterService
-  
- GetCommandParser - Class in com.hazelcast.internal.ascii.memcache
-  
- GetCommandParser() - Constructor for class com.hazelcast.internal.ascii.memcache.GetCommandParser
-  
- GetCommandProcessor - Class in com.hazelcast.internal.ascii.memcache
-  
- GetCommandProcessor(TextCommandService, boolean) - Constructor for class com.hazelcast.internal.ascii.memcache.GetCommandProcessor
-  
- getCommittedHeap() - Method in class com.hazelcast.memory.DefaultMemoryStats
-  
- getCommittedHeap() - Method in interface com.hazelcast.memory.MemoryStats
- 
Returns the amount of memory in bytes that is committed for
 the Java virtual machine to use. 
- getCommittedHeap() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- getCommittedNativeMemory() - Method in class com.hazelcast.memory.DefaultMemoryStats
-  
- getCommittedNativeMemory() - Method in interface com.hazelcast.memory.MemoryStats
- 
Returns the amount of native memory in bytes that is committed for
 current HazelcastInstance to use. 
- getCommittedNativeMemory() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- getComparator(EvictionPolicy) - Static method in class com.hazelcast.map.impl.nearcache.NearCacheRecord
-  
- getComparator() - Method in class com.hazelcast.query.PagingPredicate
-  
- getCompletableFuture() - Method in class com.hazelcast.mapreduce.impl.task.TrackableJobFuture
-  
- getCompletableFuture() - Method in interface com.hazelcast.mapreduce.TrackableJob
- 
Returns the  ICompletableFuture to add callbacks
 or wait for the resulting value of the tracked job. 
- getCompletedMigrations() - Method in class com.hazelcast.partition.PartitionRuntimeState
-  
- getCompletedTaskCount() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-  
- getCompletedTaskCount() - Method in interface com.hazelcast.monitor.LocalExecutorStats
- 
Returns the number of completed operations on the executor service. 
- getCompletedTaskCount() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-  
- getCompletedTaskCount() - Method in interface com.hazelcast.util.executor.ManagedExecutorService
-  
- getCompletionId() - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- getCompletionId() - Method in class com.hazelcast.cache.impl.CacheEventSet
-  
- getCompletionId() - Method in class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
-  
- getCompletionId() - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
-  
- getCompletionId() - Method in interface com.hazelcast.cache.impl.operation.MutableOperation
-  
- getConcurrencyLevel() - Method in class com.hazelcast.config.ReplicatedMapConfig
- 
Deprecated.
new implementation doesn't use mutexes 
 
- getConditionId() - Method in class com.hazelcast.concurrent.lock.ConditionKey
-  
- getConfig() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- getConfig() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Gets the configuration of the cache that this store belongs to. 
- getConfig() - Method in interface com.hazelcast.client.ClientEngine
-  
- getConfig() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- getConfig() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getConfig() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getConfig(NodeEngine) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-  
- getConfig() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- getConfig() - Method in class com.hazelcast.collection.impl.list.ListContainer
-  
- getConfig(NodeEngine) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
-  
- getConfig() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- getConfig() - Method in class com.hazelcast.collection.impl.set.SetContainer
-  
- getConfig(NodeEngine) - Method in class com.hazelcast.collection.impl.set.SetProxyImpl
-  
- getConfig() - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the configuration of this Hazelcast instance. 
- getConfig() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getConfig() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getConfig() - Method in class com.hazelcast.instance.Node
-  
- getConfig() - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getConfig() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getConfig() - Method in class com.hazelcast.jmx.MapMBean
-  
- getConfig() - Method in class com.hazelcast.jmx.QueueMBean
-  
- getConfig() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- getConfig() - Method in class com.hazelcast.jmx.TopicMBean
-  
- getConfig() - Method in class com.hazelcast.quorum.impl.QuorumImpl
-  
- getConfig() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-  
- getConfig() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getConfig() - Method in interface com.hazelcast.spi.NodeEngine
- 
Returns the Config that was used to create the HazelcastInstance. 
- getConfigCheck() - Method in class com.hazelcast.cluster.impl.JoinMessage
-  
- getConfigClassLoader() - Method in class com.hazelcast.instance.Node
-  
- getConfigClassLoader() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-  
- getConfigClassLoader() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getConfigClassLoader() - Method in interface com.hazelcast.spi.NodeEngine
- 
Returns the Config ClassLoader. 
- getConfigFilePath(Properties) - Static method in class com.hazelcast.hibernate.CacheEnvironment
-  
- getConfigLocation() - Method in class com.hazelcast.jca.ResourceAdapterImpl
- 
Deprecated. 
- getConfigObject() - Method in class com.hazelcast.config.ServiceConfig
-  
- getConfigPatternMatcher() - Method in class com.hazelcast.config.Config
-  
- getConfigSource() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getConfiguration(Class<C>) - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- getConfiguration(Class<C>) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- getConfiguration() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-  
- getConfigurationFile() - Method in class com.hazelcast.config.Config
-  
- getConfigurationFile() - Method in class com.hazelcast.config.XmlConfigLocator
-  
- getConfigurationLocation() - Method in class com.hazelcast.jca.ResourceAdapterImpl
-  
- getConfigurationMembers(Config) - Static method in class com.hazelcast.cluster.impl.TcpIpJoiner
-  
- getConfigurationProperties() - Method in class com.hazelcast.jclouds.JCloudsDiscoveryStrategyFactory
-  
- getConfigurationProperties() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategyFactory
- 
Returns a set of the expected configuration properties. 
- getConfigurationUrl() - Method in class com.hazelcast.config.Config
-  
- getConfigurationUrl() - Method in class com.hazelcast.config.XmlConfigLocator
-  
- getConfiguredValue() - Static method in enum com.hazelcast.nio.tcp.nonblocking.SelectorMode
-  
- getConn() - Method in class com.hazelcast.nio.Packet
- 
Gets the Connection this Packet was send with. 
- getConnectedClients() - Method in class com.hazelcast.client.impl.ClientServiceProxy
-  
- getConnectedClients() - Method in interface com.hazelcast.core.ClientService
- 
Returns all connected clients to this member. 
- GetConnectedClientsOperation - Class in com.hazelcast.client.impl.operations
-  
- GetConnectedClientsOperation() - Constructor for class com.hazelcast.client.impl.operations.GetConnectedClientsOperation
-  
- getConnectedClientStats() - Method in interface com.hazelcast.client.ClientEngine
- 
Returns Map which contains number of connected clients to the cluster. 
- getConnectedClientStats() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- getConnection() - Method in interface com.hazelcast.client.ClientEndpoint
-  
- getConnection(Address) - Method in interface com.hazelcast.client.connection.ClientConnectionManager
-  
- getConnection(Address) - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-  
- getConnection() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- getConnection() - Method in class com.hazelcast.client.proxy.txn.TransactionContextProxy
-  
- getConnection() - Method in class com.hazelcast.client.proxy.txn.xa.XATransactionContextProxy
-  
- getConnection() - Method in interface com.hazelcast.client.spi.ClientTransactionContext
-  
- getConnection() - Method in class com.hazelcast.client.txn.proxy.xa.XATransactionContextProxy
-  
- getConnection() - Method in class com.hazelcast.client.txn.TransactionContextProxy
-  
- getConnection() - Method in class com.hazelcast.jca.ConnectionFactoryImpl
-  
- getConnection(ConnectionSpec) - Method in class com.hazelcast.jca.ConnectionFactoryImpl
-  
- getConnection() - Method in interface com.hazelcast.jca.HazelcastConnectionFactory
-  
- getConnection(ConnectionSpec) - Method in interface com.hazelcast.jca.HazelcastConnectionFactory
-  
- getConnection(Subject, ConnectionRequestInfo) - Method in class com.hazelcast.jca.ManagedConnectionImpl
-  
- getConnection(Address) - Method in interface com.hazelcast.nio.ConnectionManager
- 
Gets the connection for a given address. 
- getConnection(Address) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- getConnection() - Method in class com.hazelcast.spi.Operation
-  
- getConnectionAttemptLimit() - Method in class com.hazelcast.client.config.ClientConfig
- 
Deprecated. 
- getConnectionAttemptLimit() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-  
- getConnectionAttemptPeriod() - Method in class com.hazelcast.client.config.ClientConfig
- 
Deprecated. 
- getConnectionAttemptPeriod() - Method in class com.hazelcast.client.config.ClientNetworkConfig
- 
Period for the next attempt to find a member to connect. 
- getConnectionCount() - Method in class com.hazelcast.jmx.ConnectionManagerMBean
-  
- getConnectionCount() - Method in interface com.hazelcast.nio.ConnectionManager
- 
Gets the total number of connections. 
- getConnectionCount() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- getConnectionId() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- getConnectionListener() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- getConnectionManager() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- getConnectionManager() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getConnectionManager() - Method in class com.hazelcast.instance.Node
-  
- getConnectionManager() - Method in class com.hazelcast.jmx.ConnectionManagerMBean
-  
- getConnectionManager() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- getConnectionManagerBean() - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
-  
- getConnectionManagerMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getConnectionMonitorInterval() - Method in interface com.hazelcast.nio.IOService
-  
- getConnectionMonitorInterval() - Method in class com.hazelcast.nio.NodeIOService
-  
- getConnectionMonitorMaxFaults() - Method in interface com.hazelcast.nio.IOService
-  
- getConnectionMonitorMaxFaults() - Method in class com.hazelcast.nio.NodeIOService
-  
- getConnectionTimeout() - Method in class com.hazelcast.client.config.ClientConfig
- 
Deprecated. 
- getConnectionTimeout() - Method in class com.hazelcast.client.config.ClientNetworkConfig
- 
Timeout value in millis for nodes to accept client connection requests. 
- getConnectionTimeoutSeconds() - Method in class com.hazelcast.config.AwsConfig
- 
Gets the connection timeout in seconds. 
- getConnectionTimeoutSeconds() - Method in class com.hazelcast.config.TcpIpConfig
- 
Returns the connection timeout. 
- getConnectionTracingEvents() - Method in class com.hazelcast.jca.ManagedConnectionFactoryImpl
- 
Getter for the RAR property 'connectionTracingEvents' 
- getConnTimeoutSeconds() - Method in class com.hazelcast.cluster.impl.TcpIpJoiner
-  
- getConnTimeoutSeconds() - Method in class com.hazelcast.cluster.impl.TcpIpJoinerOverAWS
-  
- getContainer() - Method in class com.hazelcast.collection.impl.queue.QueueItem
-  
- getContainer(String) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-  
- getContainerMap() - Method in class com.hazelcast.collection.impl.collection.CollectionService
-  
- getContainerMap() - Method in class com.hazelcast.collection.impl.list.ListService
-  
- getContainerMap() - Method in class com.hazelcast.collection.impl.set.SetService
-  
- getContainers() - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-  
- getContentType() - Method in class com.hazelcast.internal.ascii.rest.HttpPostCommand
-  
- getContentType() - Method in class com.hazelcast.internal.ascii.rest.RestValue
-  
- getContext() - Method in class com.hazelcast.client.spi.ClientProxy
-  
- getConverter() - Method in enum com.hazelcast.query.impl.AttributeType
-  
- getConverter() - Method in interface com.hazelcast.query.impl.Index
- 
Return converter associated with this Index. 
- getConverter() - Method in class com.hazelcast.query.impl.IndexImpl
- 
Provides comparable null object. 
- getCorrelationId() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
- 
Returns the correlation id field. 
- getCost() - Method in interface com.hazelcast.core.EntryView
- 
Returns the cost (in bytes) of the entry. 
- getCost() - Method in class com.hazelcast.map.impl.nearcache.NearCacheRecord
-  
- getCost() - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- getCost() - Method in interface com.hazelcast.map.impl.record.Record
-  
- getCost() - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- getCost() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- getCount() - Method in class com.hazelcast.cache.impl.CacheKeyIteratorResult
-  
- getCount() - Method in class com.hazelcast.client.proxy.ClientCountDownLatchProxy
-  
- getCount() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
-  
- getCount() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
-  
- getCount(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-  
- getCount() - Method in interface com.hazelcast.core.ICountDownLatch
- 
Returns the current count. 
- getCount() - Method in class com.hazelcast.jmx.CountDownLatchMBean
-  
- getCountDownLatch(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getCountDownLatch(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getCountDownLatch(String) - Method in interface com.hazelcast.core.HazelcastInstance
- 
Creates cluster-wide CountDownLatch. 
- getCountDownLatch(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getCountDownLatch(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getCountDownLatch(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getCountDownLatchContainer(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-  
- GetCountOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
-  
- GetCountOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.GetCountOperation
-  
- GetCountOperation(String) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.GetCountOperation
-  
- GetCountRequest - Class in com.hazelcast.concurrent.countdownlatch.client
-  
- GetCountRequest() - Constructor for class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-  
- GetCountRequest(String) - Constructor for class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-  
- getCreationTime() - Method in interface com.hazelcast.cache.CacheStatistics
- 
Gets the cache creation time. 
- getCreationTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- getCreationTime() - Method in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-  
- getCreationTime() - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-  
- getCreationTime() - Method in class com.hazelcast.collection.impl.collection.CollectionItem
-  
- getCreationTime() - Method in class com.hazelcast.collection.impl.queue.QueueItem
-  
- getCreationTime() - Method in interface com.hazelcast.core.EntryView
- 
Returns the creation time of the entry. 
- getCreationTime() - Method in interface com.hazelcast.internal.eviction.Evictable
- 
Gets the creation time of this  Evictable in milliseconds. 
- getCreationTime() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- getCreationTime() - Method in interface com.hazelcast.map.impl.querycache.event.QueryCacheEventData
-  
- getCreationTime() - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- getCreationTime() - Method in interface com.hazelcast.map.impl.record.Record
-  
- getCreationTime() - Method in class com.hazelcast.map.impl.record.RecordInfo
-  
- getCreationTime() - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-  
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-  
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-  
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalOperationStatsImpl
-  
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalTopicStatsImpl
-  
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalWanStatsImpl
-  
- getCreationTime() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-  
- getCreationTime() - Method in interface com.hazelcast.monitor.LocalInstanceStats
-  
- getCreationTime() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns the creation time of this map on this member. 
- getCreationTime() - Method in interface com.hazelcast.monitor.LocalTopicStats
- 
Returns the creation time of this topic on this member 
- getCreationTime() - Method in interface com.hazelcast.monitor.NearCacheStats
- 
Returns the creation time of this NearCache on this member 
- getCreationTime() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-  
- getCreationTime() - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
-  
- getCreationTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- getCreationTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-  
- getCreationTime() - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- getCredentialFromFile(String, String) - Method in class com.hazelcast.jclouds.ComputeServiceBuilder
-  
- getCredentials() - Method in interface com.hazelcast.client.ClientEndpoint
-  
- getCredentials() - Method in class com.hazelcast.client.config.ClientConfig
- 
- getCredentials() - Method in class com.hazelcast.client.config.ClientSecurityConfig
-  
- getCredentials() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- getCredentials() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getCredentials() - Method in class com.hazelcast.cluster.impl.JoinRequest
-  
- getCredentials() - Method in class com.hazelcast.jclouds.IAMRoleCredentialSupplierBuilder
-  
- getCredentialsClassname() - Method in class com.hazelcast.client.config.ClientSecurityConfig
-  
- getCredentialScope() - Method in class com.hazelcast.aws.security.EC2RequestSigner
-  
- getCredentialsFactory() - Method in interface com.hazelcast.security.SecurityContext
- 
- getCurrConnections() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- getCurrentClientConnections() - Method in class com.hazelcast.jmx.ConnectionManagerMBean
-  
- getCurrentClientConnections() - Method in interface com.hazelcast.nio.ConnectionManager
- 
Gets the number of client connections. 
- getCurrentClientConnections() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- getCurrentMembers() - Method in class com.hazelcast.quorum.QuorumEvent
- 
Returns the snapshot of member list at the time quorum happened 
- getCurrentOperationRunner() - Method in class com.hazelcast.spi.impl.operationexecutor.classic.OperationThread
-  
- getCurrentValue() - Method in class com.hazelcast.jmx.AtomicLongMBean
-  
- getCxRequestInfo() - Method in class com.hazelcast.jca.ManagedConnectionImpl
-  
- getData() - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- getData() - Method in class com.hazelcast.collection.impl.collection.CollectionEvent
-  
- getData() - Method in class com.hazelcast.collection.impl.queue.QueueItem
-  
- getData() - Method in class com.hazelcast.internal.ascii.rest.HttpPostCommand
-  
- getDataEntrySet() - Method in class com.hazelcast.multimap.impl.operations.EntrySetResponse
-  
- getDataFromMap(long) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- getDataItems() - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
-  
- getDataItems() - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
-  
- getDataKey() - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- getDataKey() - Method in interface com.hazelcast.cache.impl.CacheEventData
- 
Gets cache entry key as  Data. 
- getDataKey() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-  
- getDataKey() - Method in class com.hazelcast.map.impl.event.EntryEventData
-  
- getDataKey() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- getDataKey() - Method in interface com.hazelcast.map.impl.querycache.event.QueryCacheEventData
-  
- getDataList() - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- getDataLoadTimeoutSeconds() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
- 
Returns configured data load timeout for hot-restart process. 
- getDataMemberCount() - Method in class com.hazelcast.cluster.impl.JoinMessage
-  
- getDataMergingValue() - Method in class com.hazelcast.map.impl.event.EntryEventData
-  
- getDataNewValue() - Method in class com.hazelcast.map.impl.event.EntryEventData
-  
- getDataNewValue() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- getDataNewValue() - Method in interface com.hazelcast.map.impl.querycache.event.QueryCacheEventData
-  
- getDataOffset() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
- 
Returns the setDataOffset field. 
- getDataOldValue() - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- getDataOldValue() - Method in interface com.hazelcast.cache.impl.CacheEventData
- 
Gets the old value of entry as  Data, if available. 
- getDataOldValue() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-  
- getDataOldValue() - Method in class com.hazelcast.map.impl.event.EntryEventData
-  
- getDataOldValue() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- getDataOldValue() - Method in interface com.hazelcast.map.impl.querycache.event.QueryCacheEventData
-  
- getDataSerializableFactories() - Method in class com.hazelcast.config.SerializationConfig
-  
- getDataSerializableFactoryClasses() - Method in class com.hazelcast.config.SerializationConfig
-  
- getDataValue() - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- getDataValue() - Method in interface com.hazelcast.cache.impl.CacheEventData
- 
Gets cache entry value as  Data. 
- getDataValue() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-  
- getDecodedDataLength(byte[]) - Static method in class com.hazelcast.util.Base64
- 
returns length of decoded data given an
 array containing encoded data. 
- getDecrHits() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- getDecrMisses() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- getDefault() - Static method in enum com.hazelcast.cache.BuiltInCacheMergePolicies
- 
- getDefault() - Static method in class com.hazelcast.transaction.TransactionOptions
- 
Creates a new TransactionOptions configured with default settings. 
- getDefaultAccessType() - Method in class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
-  
- getDefaultCacheTimeoutInMillis() - Static method in class com.hazelcast.hibernate.CacheEnvironment
-  
- getDefaultClassLoader() - Method in class com.hazelcast.cache.HazelcastCachingProvider
-  
- getDefaultClassLoader() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-  
- getDefaultEvictionStrategy() - Static method in class com.hazelcast.internal.eviction.EvictionStrategyProvider
- 
- getDefaultHazelcastInstance() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
- 
- getDefaultMapServiceConstructor() - Static method in class com.hazelcast.map.impl.MapServiceConstructor
- 
- getDefaultProperties() - Method in class com.hazelcast.cache.HazelcastCachingProvider
-  
- getDefaultProperties() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-  
- getDefaultScheduledExecutor() - Method in interface com.hazelcast.spi.ExecutionService
-  
- getDefaultScheduledExecutor() - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-  
- getDefaultURI() - Method in class com.hazelcast.cache.HazelcastCachingProvider
-  
- getDefaultURI() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-  
- getDefaultValue() - Method in enum com.hazelcast.client.config.ClientProperty
-  
- getDefaultValue() - Method in enum com.hazelcast.instance.GroupProperty
-  
- getDefaultValue() - Method in interface com.hazelcast.instance.HazelcastProperty
- 
Returns the default value of the property. 
- getDelaySeconds() - Method in class com.hazelcast.config.QueryCacheConfig
- 
Returns the minimum number of delay seconds which an event waits in the buffer of node
 before sending to a QueryCache
 
- getDelegatedInstance() - Method in interface com.hazelcast.osgi.HazelcastOSGiInstance
- 
- getDeleteHits() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- getDeleteMisses() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- getDestination() - Method in class com.hazelcast.partition.MigrationInfo
-  
- getDetails() - Method in class com.hazelcast.client.impl.client.GenericError
-  
- getDirtyEntryCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getDirtyEntryCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getDirtyEntryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns the number of entries that the member owns and are dirty (updated but not persisted yet). 
- getDiscoveryConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
- 
Returns the configuration of the Hazelcast Discovery SPI and configured discovery providers 
- getDiscoveryConfig() - Method in class com.hazelcast.config.JoinConfig
- 
- getDiscoveryConfig() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-  
- getDiscoveryMode() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-  
- getDiscoveryNode() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-  
- getDiscoveryServiceProvider() - Method in class com.hazelcast.config.DiscoveryConfig
-  
- getDiscoveryStrategyConfigs() - Method in class com.hazelcast.config.DiscoveryConfig
- 
- getDiscoveryStrategyFactory() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
-  
- getDiscoveryStrategyType() - Method in class com.hazelcast.jclouds.JCloudsDiscoveryStrategyFactory
-  
- getDiscoveryStrategyType() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategyFactory
- 
- getDistributedObject(String, String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getDistributedObject(String, String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getDistributedObject() - Method in class com.hazelcast.client.spi.impl.listener.LazyDistributedObjectEvent
-  
- getDistributedObject() - Method in class com.hazelcast.core.DistributedObjectEvent
- 
Returns the DistributedObject instance. 
- getDistributedObject(String, String) - Method in interface com.hazelcast.core.HazelcastInstance
-  
- getDistributedObject(String, String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getDistributedObject(String, String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getDistributedObject(String, String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getDistributedObject(String, String) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-  
- getDistributedObject(String, String) - Method in interface com.hazelcast.spi.ProxyService
-  
- getDistributedObjectName() - Method in class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.cache.impl.client.CacheAddPartitionLostListenerRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.cache.impl.client.CacheClearRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.cache.impl.client.CacheContainsKeyRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.cache.impl.client.CacheEntryProcessorRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.cache.impl.client.CacheGetAndRemoveRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.cache.impl.client.CacheGetRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.cache.impl.client.CacheIterateRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.cache.impl.client.CachePutAllRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.cache.impl.client.CachePutIfAbsentRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.cache.impl.client.CachePutRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.cache.impl.client.CacheRemoveEntryListenerRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.cache.impl.client.CacheRemoveRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.cache.impl.client.CacheReplaceRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.client.ClientRequest
-  
- getDistributedObjectName() - Method in interface com.hazelcast.client.impl.client.SecureRequest
- 
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAddAndGetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterAndGetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongApplyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongCompareAndSetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongDecrementAndGetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAddMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAlterMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndIncrementMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndSetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongIncrementAndGetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongSetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterAndGetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceApplyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceClearMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceCompareAndSetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceContainsMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndAlterMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndSetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceIsNullMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetAndGetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationCustomCredentialsMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddEntryListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddInvalidationListenerTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheContainsKeyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheCreateConfigMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEntryProcessorMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndRemoveMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndReplaceMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetConfigMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutIfAbsentMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheReplaceMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheSizeMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionAwaitMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionBeforeAwaitMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchAwaitMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchCountDownMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchGetCountMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchTrySetCountMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnAddressMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceCancelOnPartitionMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllWithIndexMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddWithIndexMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListClearMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRemoveAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRetainAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIndexOfMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIsEmptyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIteratorMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListLastIndexOfMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListListIteratorMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveWithIndexMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSizeMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSubMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockForceUnlockMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockGetLockCountMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockGetRemainingLeaseTimeMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockIsLockedByCurrentThreadMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockIsLockedMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockLockMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockTryLockMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockUnlockMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyWithPredicateMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerWithPredicateMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddIndexMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddInterceptorMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddNearCacheEntryListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearNearCacheMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsKeyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsValueMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapDeleteMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPagingPredicateMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPredicateMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntrySetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnAllKeysMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeysMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteWithPredicateMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetEntryViewMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPagingPredicateMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutTransientMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveEntryListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveIfSameMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveInterceptorMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemovePartitionLostListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapReplaceIfSameMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapReplaceMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSizeMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSubmitToKeyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryLockMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryPutMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryRemoveMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapUnlockMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPagingPredicateMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPredicateMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceCancelMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForCustomMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForListMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMapMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMultiMapMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForSetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceJobProcessInformationMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerToKeyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapClearMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsEntryMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsKeyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsValueMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapGetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapPutMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValueCountMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.NoSuchMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueClearMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRemoveAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRetainAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMaxSizeMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIsEmptyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIteratorMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueOfferMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePeekMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePollMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePutMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemainingCapacityMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueSizeMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueTakeMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerWithPredicateMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddNearCacheListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsKeyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsValueMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapEntrySetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapIsEmptyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapKeySetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapSizeMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapValuesMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferCapacityMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferHeadSequenceMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadManyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadOneMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferRemainingCapacityMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferSizeMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferTailSequenceMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreAcquireMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreAvailablePermitsMessageTasks
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreDrainPermitsMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreInitMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreReducePermitsMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreReleaseMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreTryAcquireMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetClearMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRemoveAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRetainAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetGetAllMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetIsEmptyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetSizeMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicAddMessageListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicPublishMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicRemoveMessageListenerMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCommitMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCreateMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionRollbackMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAClearRemoteTransactionMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XACollectTransactionsMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAFinalizeTransactionMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCommitMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCreateMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionPrepareMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionRollbackMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListAddMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListRemoveMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListSizeMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapContainsKeyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapDeleteMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetForUpdateMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapIsEmptyMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetWithPredicateMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutIfAbsentMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveIfSameMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceIfSameMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSizeMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesWithPredicateMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapGetMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapPutMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveEntryMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapSizeMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapValueCountMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueOfferMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePeekMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePollMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueSizeMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueTakeMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetAddMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetRemoveMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetSizeMessageTask
-  
- getDistributedObjectName() - Method in class com.hazelcast.collection.impl.collection.client.CollectionAddListenerRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.collection.impl.collection.client.CollectionRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.collection.impl.queue.client.AddListenerRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.collection.impl.queue.client.QueueRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.atomiclong.client.ReadRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.atomicreference.client.AbstractAlterRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.atomicreference.client.ModifyRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.atomicreference.client.ReadRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.lock.client.AwaitRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.lock.client.SignalRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.semaphore.client.SemaphoreRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapAddIndexRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapAddPartitionLostListenerRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapClearNearCacheRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapClearRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapContainsKeyRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapContainsValueRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapDeleteRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapEvictAllRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapEvictRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapFlushRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapGetAllRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapGetRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapIsEmptyRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapIsLockedRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapLockRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapPutAllRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapPutRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapRemovePartitionLostListenerRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapSizeRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapUnlockRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.multimap.impl.client.MultiMapAllPartitionRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.multimap.impl.client.MultiMapIsLockedRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.multimap.impl.client.MultiMapLockRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.multimap.impl.client.MultiMapRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.multimap.impl.client.MultiMapUnlockRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.partition.client.AddPartitionLostListenerRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapClearRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.ringbuffer.impl.client.AddAllRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.ringbuffer.impl.client.AddRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.ringbuffer.impl.client.CapacityRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.ringbuffer.impl.client.HeadSequenceRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.ringbuffer.impl.client.ReadManyRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.ringbuffer.impl.client.ReadOneRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.ringbuffer.impl.client.RemainingCapacityRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.ringbuffer.impl.client.RingbufferRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.ringbuffer.impl.client.SizeRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.ringbuffer.impl.client.TailSequenceRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-  
- getDistributedObjectName() - Method in class com.hazelcast.topic.impl.client.PublishRequest
-  
- getDistributedObjectNames() - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyRegistry
-  
- getDistributedObjectNames(String) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-  
- getDistributedObjectNames(String) - Method in interface com.hazelcast.spi.ProxyService
-  
- getDistributedObjects() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getDistributedObjects() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getDistributedObjects() - Method in class com.hazelcast.client.spi.ProxyManager
-  
- getDistributedObjects() - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns all  DistributedObject's such as; queue, map, set, list, topic, lock, multimap. 
- getDistributedObjects() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getDistributedObjects() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getDistributedObjects() - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getDistributedObjects(Collection<DistributedObject>) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyRegistry
- 
Gets the DistributedObjects in this registry. 
- getDistributedObjects(String) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-  
- getDistributedObjects(String) - Method in interface com.hazelcast.spi.ProxyService
-  
- GetDistributedObjectsMessageTask - Class in com.hazelcast.client.impl.protocol.task
-  
- GetDistributedObjectsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
-  
- GetDistributedObjectsRequest - Class in com.hazelcast.client.impl.client
-  
- GetDistributedObjectsRequest() - Constructor for class com.hazelcast.client.impl.client.GetDistributedObjectsRequest
-  
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.client.ClientRequest
-  
- getDistributedObjectType() - Method in interface com.hazelcast.client.impl.client.SecureRequest
- 
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-  
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
-  
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
-  
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
-  
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryLockMessageTask
-  
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapUnlockMessageTask
-  
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
-  
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
-  
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
-  
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
-  
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
-  
- getDistributedObjectType() - Method in class com.hazelcast.map.impl.client.MapIsLockedRequest
-  
- getDistributedObjectType() - Method in class com.hazelcast.map.impl.client.MapLockRequest
-  
- getDistributedObjectType() - Method in class com.hazelcast.map.impl.client.MapUnlockRequest
-  
- getDistributedObjectType() - Method in class com.hazelcast.multimap.impl.client.MultiMapIsLockedRequest
-  
- getDistributedObjectType() - Method in class com.hazelcast.multimap.impl.client.MultiMapLockRequest
-  
- getDistributedObjectType() - Method in class com.hazelcast.multimap.impl.client.MultiMapUnlockRequest
-  
- getDouble(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
- 
Returns a field in a Json object as a double. 
- getDouble(JsonObject, String, double) - Static method in class com.hazelcast.util.JsonUtil
- 
Returns a field in a Json object as a double. 
- getDoubleAttribute(String) - Method in class com.hazelcast.client.impl.MemberImpl
-  
- getDoubleAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-  
- getDoubleAttribute(String) - Method in interface com.hazelcast.core.Member
- 
Returns the value of the specified key for this member or
 null if value is undefined. 
- getDoubleAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-  
- getDurability() - Method in class com.hazelcast.transaction.TransactionOptions
- 
Gets the transaction durability. 
- getDurationAmount() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
-  
- getDurationConfig() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
-  
- getEmpty() - Method in class com.hazelcast.jmx.suppliers.LocalMapStatsSupplier
-  
- getEmpty() - Method in class com.hazelcast.jmx.suppliers.LocalMultiMapStatsSupplier
-  
- getEmpty() - Method in class com.hazelcast.jmx.suppliers.LocalQueueStatsSupplier
-  
- getEmpty() - Method in interface com.hazelcast.jmx.suppliers.StatsSupplier
-  
- getEmptyPollOperationCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- getEmptyPollOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
- 
Returns number of null returning poll operations. 
- getEmptyQueueTtl() - Method in class com.hazelcast.config.QueueConfig
- 
Returns the TTL (time to live) for emptying the Queue. 
- getEndpoint() - Method in class com.hazelcast.aws.AWSClient
-  
- getEndpoint(Connection) - Method in interface com.hazelcast.client.ClientEndpointManager
- 
Gets the endpoint for a given connection. 
- getEndPoint() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- getEndpoint() - Method in class com.hazelcast.client.impl.client.ClientRequest
-  
- getEndpoint(Connection) - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-  
- getEndpoint() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-  
- getEndpoint() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
-  
- getEndPoint() - Method in interface com.hazelcast.nio.Connection
- 
Gets the  Address of the other side of this Connection. 
- getEndPoint() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- getEndPoint() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionMonitor
-  
- getEndpoint() - Method in class com.hazelcast.partition.PartitionRuntimeState
-  
- getEndpoint() - Method in class com.hazelcast.security.AbstractCredentials
-  
- getEndpoint() - Method in interface com.hazelcast.security.Credentials
- 
Returns IP address of endpoint. 
- getEndpointManager() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- getEndpoints() - Method in interface com.hazelcast.client.ClientEndpointManager
- 
Returns the current endpoints. 
- getEndpoints(String) - Method in interface com.hazelcast.client.ClientEndpointManager
- 
Gets all the endpoints for a given client. 
- getEndpoints(String) - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-  
- getEndpoints() - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-  
- getEndpoints() - Method in class com.hazelcast.config.PermissionConfig
-  
- getEndpoints() - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- getEngineByExtension(String) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
-  
- getEngineByMimeType(String) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
-  
- getEngineByName(String) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
-  
- getEngineFactories() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
-  
- getEngineName() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
-  
- getEngineVersion() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
-  
- getEntries() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
-  
- getEntryCount() - Method in class com.hazelcast.cache.impl.CacheContext
-  
- getEntryCount() - Method in class com.hazelcast.cache.impl.CacheEntryCountResolver
-  
- getEntryListenerConfigs() - Method in class com.hazelcast.config.MapConfig
-  
- getEntryListenerConfigs() - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- getEntryListenerConfigs() - Method in class com.hazelcast.config.MultiMapConfig
- 
Gets the list of entry listeners (listens for when entries are added or removed) for this MultiMap. 
- getEntryListenerConfigs() - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-  
- getEntryListenerConfigs() - Method in class com.hazelcast.config.QueryCacheConfig
-  
- getEntryObject() - Method in class com.hazelcast.query.PredicateBuilder
-  
- getEntrySet() - Method in class com.hazelcast.multimap.impl.client.PortableEntrySetResponse
-  
- getEntryView(K) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- getEntryView(K) - Method in interface com.hazelcast.core.IMap
- 
Returns the EntryView for the specified key. 
- getEntryView(K) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- getEntryView() - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
-  
- GetEntryViewOperation - Class in com.hazelcast.map.impl.operation
-  
- GetEntryViewOperation() - Constructor for class com.hazelcast.map.impl.operation.GetEntryViewOperation
-  
- GetEntryViewOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.GetEntryViewOperation
-  
- getEnum(GroupProperty, Class<E>) - Method in class com.hazelcast.instance.HazelcastProperties
- 
- getEvent() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventEnvelope
-  
- getEventCount() - Method in interface com.hazelcast.nio.tcp.nonblocking.MigratableHandler
- 
Get number of events recorded by the current handler. 
- getEventCount() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingIOThread
- 
Returns the total number of selection-key events that have been processed by this thread. 
- getEventCount() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingSocketReader
-  
- getEventCount() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingSocketWriter
-  
- getEventExecutor() - Method in class com.hazelcast.client.spi.impl.listener.ClientListenerServiceImpl
-  
- getEventFilter() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapAddEntryListenerMessageTask
-  
- getEventFilter() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerMessageTask
-  
- getEventFilter() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyMessageTask
-  
- getEventFilter() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyWithPredicateMessageTask
-  
- getEventFilter() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerWithPredicateMessageTask
-  
- getEventFilter() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddNearCacheEntryListenerMessageTask
-  
- getEventFilter() - Method in class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-  
- getEventFilter() - Method in class com.hazelcast.map.impl.EventListenerFilter
-  
- getEventHandler() - Method in class com.hazelcast.client.spi.impl.ClientInvocation
-  
- getEventHandler(long) - Method in class com.hazelcast.client.spi.impl.listener.ClientListenerServiceImpl
-  
- getEventId() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventEnvelope
-  
- getEventObject() - Method in class com.hazelcast.wan.WanReplicationEvent
- 
Gets the event object. 
- getEventOperationCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getEventOperationCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- getEventOperationCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getEventOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns the number of Events Received 
- getEventOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
- 
Returns number of event operations 
- getEventPublishingService() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- getEventQueueCapacity() - Method in class com.hazelcast.jmx.EventServiceMBean
-  
- getEventQueueCapacity() - Method in interface com.hazelcast.spi.EventService
- 
Returns the queue capacity per event thread. 
- getEventQueueCapacity() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-  
- getEventQueueSize() - Method in class com.hazelcast.jmx.EventServiceMBean
-  
- getEventQueueSize() - Method in interface com.hazelcast.spi.EventService
- 
Returns the current total event queue size. 
- getEventQueueSize() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-  
- getEvents() - Method in class com.hazelcast.cache.impl.CacheEventSet
-  
- getEventService() - Method in interface com.hazelcast.client.ClientEngine
-  
- getEventService() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- getEventService() - Method in interface com.hazelcast.nio.IOService
-  
- getEventService() - Method in class com.hazelcast.nio.NodeIOService
-  
- getEventService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getEventService() - Method in interface com.hazelcast.spi.NodeEngine
- 
Gets the EventService. 
- getEventServiceBean() - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
-  
- getEventServiceMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getEventSource() - Method in class com.hazelcast.partition.InternalPartitionLostEvent
- 
The address of the node that detects the partition lost 
- getEventSource() - Method in class com.hazelcast.partition.PartitionLostEvent
- 
Returns the address of the node that dispatches the event 
- getEventThreadCount() - Method in class com.hazelcast.jmx.EventServiceMBean
-  
- getEventThreadCount() - Method in interface com.hazelcast.spi.EventService
- 
Returns the event thread count. 
- getEventThreadCount() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-  
- getEventType() - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- getEventType() - Method in class com.hazelcast.cache.impl.CacheEventSet
-  
- getEventType() - Method in class com.hazelcast.cache.impl.event.AbstractICacheEvent
- 
- getEventType() - Method in interface com.hazelcast.cache.impl.event.ICacheEvent
- 
Return the event type 
- getEventType() - Method in class com.hazelcast.client.ClientEvent
-  
- getEventType() - Method in class com.hazelcast.cluster.client.ClientInitialMembershipEvent
- 
Returns the membership event type; #MEMBER_ADDED or #MEMBER_REMOVED 
- getEventType() - Method in class com.hazelcast.cluster.client.ClientMembershipEvent
- 
Returns the membership event type; #MEMBER_ADDED or #MEMBER_REMOVED 
- getEventType() - Method in class com.hazelcast.collection.impl.collection.CollectionEvent
-  
- getEventType() - Method in class com.hazelcast.core.AbstractIMapEvent
- 
- getEventType() - Method in class com.hazelcast.core.DistributedObjectEvent
- 
- getEventType() - Method in interface com.hazelcast.core.IMapEvent
- 
Return the event type 
- getEventType() - Method in class com.hazelcast.core.ItemEvent
- 
Returns the event type. 
- getEventType() - Method in class com.hazelcast.core.MembershipEvent
- 
Returns the membership event type;
 #MEMBER_ADDED
 #MEMBER_REMOVED
 #MEMBER_ATTRIBUTE_CHANGED 
- getEventType() - Method in interface com.hazelcast.map.impl.event.EventData
-  
- getEventType() - Method in class com.hazelcast.map.impl.nearcache.Invalidation
-  
- getEventType() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- getEventType() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-  
- getEventType() - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
-  
- getEventType() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-  
- getEventType() - Method in class com.hazelcast.spi.impl.PortableItemEvent
-  
- getEventType() - Method in class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectEventPacket
-  
- getEvictable() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.HeapNearCacheRecordMap.EvictableSamplingEntry
-  
- getEvictable() - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap.EvictableSamplingEntry
-  
- getEvictable() - Method in interface com.hazelcast.internal.eviction.EvictionCandidate
- 
The value of  Evictable entry or record or whatever. 
- getEvictionChecker() - Method in interface com.hazelcast.map.impl.eviction.Evictor
- 
Get eviction checker for this  Evictor
- getEvictionChecker() - Method in class com.hazelcast.map.impl.eviction.EvictorImpl
-  
- getEvictionConfig() - Method in class com.hazelcast.config.CacheConfig
- 
- getEvictionConfig() - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- getEvictionConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Gets the eviction configuration for this  ICache. 
- getEvictionConfig() - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- getEvictionConfig() - Method in class com.hazelcast.config.NearCacheConfig
- 
The eviction policy. 
- getEvictionConfig() - Method in class com.hazelcast.config.QueryCacheConfig
- 
- getEvictionConfig(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
-  
- getEvictionCriteriaNumber() - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- getEvictionCriteriaNumber() - Method in interface com.hazelcast.map.impl.record.Record
-  
- getEvictionCriteriaNumber() - Method in class com.hazelcast.map.impl.record.RecordInfo
-  
- getEvictionCriteriaNumber() - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- getEvictionCriteriaValue(Record, EvictionPolicy) - Method in class com.hazelcast.map.impl.eviction.EvictorImpl
-  
- getEvictionPercentage() - Method in class com.hazelcast.config.MapConfig
- 
Returns the evictionPercentage: specified percentage of the map to be evicted 
- getEvictionPolicy() - Method in class com.hazelcast.config.EvictionConfig
-  
- getEvictionPolicy() - Method in class com.hazelcast.config.MapConfig
- 
Returns the evictionPolicy 
- getEvictionPolicy() - Method in class com.hazelcast.config.NearCacheConfig
- 
The eviction policy for the near cache. 
- getEvictionPolicyEvaluator(EvictionConfiguration) - Static method in class com.hazelcast.internal.eviction.EvictionPolicyEvaluatorProvider
- 
- getEvictionPolicyType() - Method in class com.hazelcast.config.EvictionConfig
-  
- getEvictionPolicyType() - Method in interface com.hazelcast.internal.eviction.EvictionConfiguration
- 
Gets the type of eviction policy. 
- getEvictionStartIndex(long[], int) - Method in class com.hazelcast.map.impl.eviction.EvictorImpl
-  
- getEvictionStrategy(EvictionConfiguration) - Static method in class com.hazelcast.internal.eviction.EvictionStrategyProvider
- 
- getEvictionStrategyType() - Method in class com.hazelcast.config.EvictionConfig
-  
- getEvictionStrategyType() - Method in interface com.hazelcast.internal.eviction.EvictionConfiguration
- 
Gets the type of eviction strategy. 
- getEvictor() - Method in class com.hazelcast.map.impl.MapContainer
-  
- getExecutedCount() - Method in class com.hazelcast.jmx.ManagedExecutorServiceMBean
-  
- getExecutedOperationCount() - Method in class com.hazelcast.jmx.OperationServiceMBean
-  
- getExecutedOperationCount() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- getExecutedOperationCount() - Method in interface com.hazelcast.spi.OperationService
- 
Deprecated. 
- getExecutionCallback() - Method in class com.hazelcast.spi.InvocationBuilder
- 
Gets the ExecutionCallback. 
- getExecutionService() - Method in class com.hazelcast.client.spi.ClientContext
-  
- getExecutionService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getExecutionService() - Method in interface com.hazelcast.spi.NodeEngine
- 
Gets the ExecutionService. 
- getExecutor() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
- 
Gets the Executor that is going to process the events. 
- getExecutor() - Method in class com.hazelcast.config.ReliableTopicConfig
- 
Gets the Executor that is going to process the events. 
- getExecutor(String) - Method in interface com.hazelcast.spi.ExecutionService
-  
- getExecutor(String) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-  
- getExecutorConfig(String) - Method in class com.hazelcast.config.Config
- 
Returns the ExecutorConfig for the given name 
- getExecutorConfigs() - Method in class com.hazelcast.config.Config
-  
- getExecutorPoolSize() - Method in class com.hazelcast.client.config.ClientConfig
- 
Pool size for internal ExecutorService which handles responses etc. 
- getExecutorService(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getExecutorService(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getExecutorService(String) - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the distributed executor service for the given
 name. 
- getExecutorService(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getExecutorService(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getExecutorService(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getExecutorService(String) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-  
- getExistingRecordStore(int, String) - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- getExistingRecordStore(String) - Method in class com.hazelcast.map.impl.PartitionContainer
-  
- getExpiration() - Method in class com.hazelcast.internal.ascii.memcache.DeleteCommand
-  
- getExpiration() - Method in class com.hazelcast.internal.ascii.memcache.SetCommand
-  
- getExpiration() - Method in class com.hazelcast.internal.ascii.memcache.TouchCommand
-  
- getExpirationManager() - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- getExpirationTime() - Method in interface com.hazelcast.cache.CacheEntryView
- 
Gets the expiration time in milliseconds of the cache entry. 
- getExpirationTime() - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- getExpirationTime() - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
-  
- getExpirationTime() - Method in class com.hazelcast.cache.impl.merge.entry.LazyCacheEntryView
-  
- getExpirationTime() - Method in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-  
- getExpirationTime() - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-  
- getExpirationTime() - Method in interface com.hazelcast.concurrent.lock.LockResource
-  
- getExpirationTime() - Method in interface com.hazelcast.core.EntryView
- 
Returns the expiration time of the entry. 
- getExpirationTime() - Method in interface com.hazelcast.internal.eviction.Expirable
- 
Gets the expiration time in milliseconds. 
- getExpirationTime() - Method in class com.hazelcast.map.impl.record.EmptyRecordStatistics
-  
- getExpirationTime() - Method in interface com.hazelcast.map.impl.record.RecordStatistics
-  
- getExpirationTime() - Method in class com.hazelcast.map.impl.record.RecordStatisticsImpl
-  
- getExpirationTime() - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- getExpirationTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- getExpiryForAccess() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-  
- getExpiryForCreation() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-  
- getExpiryForUpdate() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-  
- getExpiryPolicy(ExpiryPolicy) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- getExpiryPolicyFactoryConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Gets the factory configuration for the ExpiryPolicy.
 
- getExpiryPolicyType() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
-  
- getExtensions() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
-  
- getExtractor() - Method in class com.hazelcast.config.MapAttributeConfig
- 
Gets the full class name of the extractor in a String format, e.g. 
- getExtractors(String) - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- getFactoryClassName() - Method in class com.hazelcast.config.MapStoreConfig
- 
Returns the name of the MapStoreFactory implementation class 
- getFactoryClassName() - Method in class com.hazelcast.config.QueueStoreConfig
-  
- getFactoryClassName() - Method in class com.hazelcast.config.SSLConfig
- 
- getFactoryId() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.CacheClearResponse
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.CacheEventSet
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.CacheKeyIteratorResult
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.CachePortableHook
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.AbstractCacheRequest
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheAddInvalidationListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheAddPartitionLostListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheClearRequest
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheCreateConfigRequest
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheDestroyRequest
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheGetAllRequest
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheInvalidationMessage
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheIterateRequest
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheManagementConfigRequest
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CachePutAllRequest
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheRemoveEntryListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheRemoveInvalidationListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheRemovePartitionLostListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheSizeRequest
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheDestroyOperation
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
-  
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
-  
- getFactoryId() - Method in class com.hazelcast.client.impl.client.AddDistributedObjectListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.client.impl.client.AuthenticationRequest
-  
- getFactoryId() - Method in class com.hazelcast.client.impl.client.ClientCreateRequest
-  
- getFactoryId() - Method in class com.hazelcast.client.impl.client.ClientDestroyRequest
-  
- getFactoryId() - Method in class com.hazelcast.client.impl.client.ClientPortableHook
-  
- getFactoryId() - Method in class com.hazelcast.client.impl.client.ClientPrincipal
-  
- getFactoryId() - Method in class com.hazelcast.client.impl.client.ClientResponse
-  
- getFactoryId() - Method in class com.hazelcast.client.impl.client.DistributedObjectInfo
-  
- getFactoryId() - Method in class com.hazelcast.client.impl.client.GenericError
-  
- getFactoryId() - Method in class com.hazelcast.client.impl.client.GetDistributedObjectsRequest
-  
- getFactoryId() - Method in class com.hazelcast.client.impl.client.GetMemberListRequest
-  
- getFactoryId() - Method in class com.hazelcast.client.impl.client.RemoveAllListeners
-  
- getFactoryId() - Method in class com.hazelcast.client.impl.client.RemoveDistributedObjectListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.client.impl.ClientDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.cluster.client.AddMembershipListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.cluster.client.ClientInitialMembershipEvent
-  
- getFactoryId() - Method in class com.hazelcast.cluster.client.ClientMembershipEvent
-  
- getFactoryId() - Method in class com.hazelcast.cluster.client.ClientPingRequest
-  
- getFactoryId() - Method in class com.hazelcast.cluster.client.RegisterMembershipListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.cluster.impl.BindMessage
-  
- getFactoryId() - Method in class com.hazelcast.cluster.impl.ClusterDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.cluster.impl.ConfigCheck
-  
- getFactoryId() - Method in class com.hazelcast.cluster.impl.operations.HeartbeatOperation
-  
- getFactoryId() - Method in class com.hazelcast.cluster.impl.operations.MemberInfoUpdateOperation
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.collection.client.CollectionAddListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.collection.client.CollectionRemoveListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.collection.client.CollectionRequest
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.collection.CollectionEvent
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.collection.CollectionEventFilter
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.collection.CollectionItem
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.collection.CollectionPortableHook
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionReplicationOperation
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.client.AddListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.client.QueueRequest
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.client.RemoveListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.operations.OfferBackupOperation
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.operations.PeekOperation
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.operations.PollBackupOperation
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.operations.QueueOperation
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.operations.QueueReplicationOperation
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.QueueEvent
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.QueueEventFilter
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.QueueItem
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.queue.QueuePortableHook
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.txncollection.client.TxnCollectionRequest
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnOfferRequest
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnPeekRequest
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnPollRequest
-  
- getFactoryId() - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnSizeRequest
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.atomiclong.client.AtomicLongPortableHook
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.atomiclong.client.ReadRequest
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.atomicreference.client.AbstractAlterRequest
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.atomicreference.client.AtomicReferencePortableHook
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.atomicreference.client.ModifyRequest
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.atomicreference.client.ReadRequest
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownLatchPortableHook
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.GetCountOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.client.AwaitRequest
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.client.BeforeAwaitRequest
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.client.IsLockedRequest
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.client.LockPortableHook
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.client.LockRequest
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.client.SignalRequest
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.client.UnlockRequest
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.LockDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.operations.BaseLockOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.client.SemaphorePortableHook
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.client.SemaphoreRequest
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireBackupOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.AvailableOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.DeadMemberBackupOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainBackupOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.InitBackupOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.InitOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceBackupOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseBackupOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
-  
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.executor.impl.client.CancellationRequest
-  
- getFactoryId() - Method in class com.hazelcast.executor.impl.client.IsShutdownRequest
-  
- getFactoryId() - Method in class com.hazelcast.executor.impl.client.PartitionTargetCallableRequest
-  
- getFactoryId() - Method in class com.hazelcast.executor.impl.client.ShutdownRequest
-  
- getFactoryId() - Method in class com.hazelcast.executor.impl.client.SpecificTargetCallableRequest
-  
- getFactoryId() - Method in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.executor.impl.ExecutorPortableHook
-  
- getFactoryId() - Method in class com.hazelcast.executor.impl.operations.CallableTaskOperation
-  
- getFactoryId() - Method in class com.hazelcast.executor.impl.operations.MemberCallableTaskOperation
-  
- getFactoryId() - Method in class com.hazelcast.executor.impl.RunnableAdapter
-  
- getFactoryId() - Method in class com.hazelcast.hibernate.distributed.AbstractRegionCacheEntryProcessor
-  
- getFactoryId() - Method in class com.hazelcast.hibernate.local.Invalidation
-  
- getFactoryId() - Method in class com.hazelcast.hibernate.local.Timestamp
-  
- getFactoryId() - Method in class com.hazelcast.hibernate.serialization.ExpiryMarker
-  
- getFactoryId() - Method in class com.hazelcast.hibernate.serialization.HibernateDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.hibernate.serialization.Value
-  
- getFactoryId() - Method in class com.hazelcast.instance.MemberImpl
-  
- getFactoryId() - Method in interface com.hazelcast.internal.serialization.DataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-  
- getFactoryId(String, int) - Static method in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- getFactoryId() - Method in class com.hazelcast.internal.serialization.impl.FieldDefinitionImpl
-  
- getFactoryId() - Method in interface com.hazelcast.internal.serialization.PortableHook
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapAddIndexRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapAddPartitionLostListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapClearNearCacheRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapClearRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapContainsKeyRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapContainsValueRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapDeleteRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapEvictAllRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapEvictRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapFlushRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapGetAllRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapGetRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapIsEmptyRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapIsLockedRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapLockRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapPutAllRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapPutRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapRemoveEntryListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapRemovePartitionLostListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapSizeRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapUnlockRequest
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.MapDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.MapEntries
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.MapKeySet
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.MapPortableHook
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.MapValueCollection
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.GetOperation
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.PutOperation
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.RemoveBackupOperation
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.RemoveOperation
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.query.QueryResult
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.query.QueryResultRow
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
-  
- getFactoryId() - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.aggregation.impl.AcceptAllSupplier
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.aggregation.impl.AvgTuple
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.aggregation.impl.KeyPredicateSupplier
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.aggregation.impl.PredicateSupplier
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.aggregation.impl.SetAdapter
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.client.ClientCancellationRequest
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.client.ClientJobProcessInformationRequest
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.CombinerResultList
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.HashMapAdapter
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.ListKeyValueSource
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.MapKeyValueSource
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.MapReducePortableHook
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.MultiMapKeyValueSource
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.notification.IntermediateChunkNotification
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.notification.LastChunkNotification
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.notification.ReducingFinishedNotification
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.CancelJobSupervisorOperation
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.FireNotificationOperation
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.GetResultOperation
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentOperation
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentResult
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.KeyValueJobOperation
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.NotifyRemoteExceptionOperation
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.PostPonePartitionProcessing
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.ProcessStatsUpdateOperation
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestMemberIdAssignment
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionMapping
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionProcessed
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionReducing
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionResult
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.StartProcessingJobOperation
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.SetKeyValueSource
-  
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.task.TransferableJobProcessInformation
-  
- getFactoryId() - Method in class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.multimap.impl.client.MultiMapAllPartitionRequest
-  
- getFactoryId() - Method in class com.hazelcast.multimap.impl.client.MultiMapIsLockedRequest
-  
- getFactoryId() - Method in class com.hazelcast.multimap.impl.client.MultiMapLockRequest
-  
- getFactoryId() - Method in class com.hazelcast.multimap.impl.client.MultiMapRequest
-  
- getFactoryId() - Method in class com.hazelcast.multimap.impl.client.MultiMapUnlockRequest
-  
- getFactoryId() - Method in class com.hazelcast.multimap.impl.client.PortableEntrySetResponse
-  
- getFactoryId() - Method in class com.hazelcast.multimap.impl.client.RemoveEntryListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRequest
-  
- getFactoryId() - Method in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.multimap.impl.MultiMapPortableHook
-  
- getFactoryId() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-  
- getFactoryId() - Method in class com.hazelcast.nio.Address
-  
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
- 
Returns the factory id. 
- getFactoryId() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
-  
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.IdentifiedDataSerializable
- 
Returns DataSerializableFactory factory id for this class. 
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.Portable
- 
Returns PortableFactory id for this portable class 
- getFactoryId() - Method in class com.hazelcast.partition.client.AddPartitionLostListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.partition.client.GetPartitionsRequest
-  
- getFactoryId() - Method in class com.hazelcast.partition.client.PartitionsResponse
-  
- getFactoryId() - Method in class com.hazelcast.partition.client.RemovePartitionLostListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.partition.PartitionDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.partition.PartitionPortableHook
-  
- getFactoryId() - Method in class com.hazelcast.partition.PartitionRuntimeState
-  
- getFactoryId() - Method in class com.hazelcast.query.impl.FalsePredicate
-  
- getFactoryId() - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
-  
- getFactoryId() - Method in class com.hazelcast.query.impl.predicates.AndPredicate
-  
- getFactoryId() - Method in class com.hazelcast.query.impl.predicates.InstanceOfPredicate
-  
- getFactoryId() - Method in class com.hazelcast.query.impl.predicates.NotPredicate
-  
- getFactoryId() - Method in class com.hazelcast.query.impl.predicates.OrPredicate
-  
- getFactoryId() - Method in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.query.PagingPredicate
-  
- getFactoryId() - Method in class com.hazelcast.query.SqlPredicate
-  
- getFactoryId() - Method in class com.hazelcast.query.TruePredicate
-  
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-  
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapClearRequest
-  
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-  
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
-  
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeys
-  
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-  
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-  
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapValueCollection
-  
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperation
-  
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- getFactoryId() - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
-  
- getFactoryId() - Method in class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
-  
- getFactoryId() - Method in class com.hazelcast.ringbuffer.impl.client.RingbufferRequest
-  
- getFactoryId() - Method in class com.hazelcast.ringbuffer.impl.operations.AbstractRingBufferOperation
-  
- getFactoryId() - Method in class com.hazelcast.ringbuffer.impl.operations.ReplicationOperation
-  
- getFactoryId() - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
-  
- getFactoryId() - Method in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.security.UsernamePasswordCredentials
-  
- getFactoryId() - Method in class com.hazelcast.spi.impl.BinaryOperationFactory
-  
- getFactoryId() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventEnvelope
-  
- getFactoryId() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
-  
- getFactoryId() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation
-  
- getFactoryId() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation.PartitionResponse
-  
- getFactoryId() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.CallTimeoutResponse
-  
- getFactoryId() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
-  
- getFactoryId() - Method in class com.hazelcast.spi.impl.PortableCachePartitionLostEvent
-  
- getFactoryId() - Method in class com.hazelcast.spi.impl.PortableCollection
-  
- getFactoryId() - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
-  
- getFactoryId() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-  
- getFactoryId() - Method in class com.hazelcast.spi.impl.PortableItemEvent
-  
- getFactoryId() - Method in class com.hazelcast.spi.impl.PortableMapPartitionLostEvent
-  
- getFactoryId() - Method in class com.hazelcast.spi.impl.PortablePartitionLostEvent
-  
- getFactoryId() - Method in class com.hazelcast.spi.impl.SerializableList
-  
- getFactoryId() - Method in class com.hazelcast.spi.impl.SpiDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.spi.impl.SpiPortableHook
-  
- getFactoryId() - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.topic.impl.client.PortableMessage
-  
- getFactoryId() - Method in class com.hazelcast.topic.impl.client.PublishRequest
-  
- getFactoryId() - Method in class com.hazelcast.topic.impl.client.RemoveMessageListenerRequest
-  
- getFactoryId() - Method in class com.hazelcast.topic.impl.PublishOperation
-  
- getFactoryId() - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicMessage
-  
- getFactoryId() - Method in class com.hazelcast.topic.impl.TopicDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.topic.impl.TopicEvent
-  
- getFactoryId() - Method in class com.hazelcast.topic.impl.TopicPortableHook
-  
- getFactoryId() - Method in class com.hazelcast.transaction.client.BaseXATransactionRequest
-  
- getFactoryId() - Method in class com.hazelcast.transaction.client.ClearRemoteTransactionRequest
-  
- getFactoryId() - Method in class com.hazelcast.transaction.client.ClientTxnPortableHook
-  
- getFactoryId() - Method in class com.hazelcast.transaction.client.CollectXATransactionsRequest
-  
- getFactoryId() - Method in class com.hazelcast.transaction.client.CommitTransactionRequest
-  
- getFactoryId() - Method in class com.hazelcast.transaction.client.CreateTransactionRequest
-  
- getFactoryId() - Method in class com.hazelcast.transaction.client.CreateXATransactionRequest
-  
- getFactoryId() - Method in class com.hazelcast.transaction.client.FinalizeXATransactionRequest
-  
- getFactoryId() - Method in class com.hazelcast.transaction.client.RollbackTransactionRequest
-  
- getFactoryId() - Method in class com.hazelcast.transaction.impl.operations.TxBaseOperation
-  
- getFactoryId() - Method in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.wan.impl.WanDataSerializerHook
-  
- getFactoryId() - Method in class com.hazelcast.wan.WanReplicationEvent
-  
- getFactoryId() - Method in class com.hazelcast.web.entryprocessor.DeleteSessionEntryProcessor
-  
- getFactoryId() - Method in class com.hazelcast.web.entryprocessor.GetAttributeEntryProcessor
-  
- getFactoryId() - Method in class com.hazelcast.web.entryprocessor.GetAttributeNamesEntryProcessor
-  
- getFactoryId() - Method in class com.hazelcast.web.entryprocessor.GetSessionStateEntryProcessor
-  
- getFactoryId() - Method in class com.hazelcast.web.entryprocessor.SessionUpdateEntryProcessor
-  
- getFactoryId() - Method in class com.hazelcast.web.SessionState
-  
- getFactoryId() - Method in class com.hazelcast.web.WebDataSerializerHook
-  
- getFactoryImpl() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
-  
- getFactoryImplementation() - Method in class com.hazelcast.config.MapStoreConfig
- 
Returns the map store factory implementation object. 
- getFactoryImplementation() - Method in class com.hazelcast.config.QueueStoreConfig
-  
- getFactoryImplementation() - Method in class com.hazelcast.config.SSLConfig
- 
- getField(String) - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-  
- getField(int) - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-  
- getField(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
- 
Gets the FieldDefinition for a particular field. 
- getField(int) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
- 
Gets the FieldDefinition for a given fieldIndex. 
- getFieldClassId(String) - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-  
- getFieldClassId(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- getFieldClassId(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
- 
Gets the class id of a field. 
- getFieldClassId(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- getFieldCount() - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-  
- getFieldCount() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
- 
Returns the field count. 
- getFieldDefinition(ClassDefinition, String) - Method in interface com.hazelcast.internal.serialization.PortableContext
-  
- getFieldNames() - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-  
- getFieldNames() - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- getFieldNames() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
- 
Returns a Set of all field names. 
- getFieldNames() - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- getFieldType(String) - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-  
- getFieldType(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- getFieldType(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
- 
Get the FieldType for a given fieldName. 
- getFieldType(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- getFilter() - Method in interface com.hazelcast.spi.EventRegistration
- 
- getFilter() - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
-  
- getFilteredNodes() - Method in class com.hazelcast.jclouds.ComputeServiceBuilder
- 
Gets filtered nodes. 
- getFilters() - Method in class com.hazelcast.config.WanReplicationRef
-  
- getFirst() - Method in class com.hazelcast.mapreduce.aggregation.impl.AvgTuple
-  
- getFirst(Iterable<T>, T) - Static method in class com.hazelcast.util.IterableUtil
-  
- getFlag() - Method in class com.hazelcast.internal.ascii.memcache.MemcacheEntry
-  
- getFlag() - Method in class com.hazelcast.internal.ascii.memcache.SetCommand
-  
- getFlags() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
- 
Returns the flags field value. 
- getFlags() - Method in class com.hazelcast.query.impl.predicates.ILikePredicate
-  
- getFlags() - Method in class com.hazelcast.query.impl.predicates.LikePredicate
-  
- getFloat(HazelcastProperty) - Method in class com.hazelcast.instance.HazelcastProperties
- 
- getFloat(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
- 
Returns a field in a Json object as a float. 
- getFloat(JsonObject, String, float) - Static method in class com.hazelcast.util.JsonUtil
- 
Returns a field in a Json object as a float. 
- getFloatAttribute(String) - Method in class com.hazelcast.client.impl.MemberImpl
-  
- getFloatAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-  
- getFloatAttribute(String) - Method in interface com.hazelcast.core.Member
- 
Returns the value of the specified key for this member or
 null if value is undefined. 
- getFloatAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-  
- getFlushCounter() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-  
- getFormatId() - Method in class com.hazelcast.transaction.impl.xa.SerializableXID
-  
- getForUpdate(Object) - Method in class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-  
- getForUpdate(Object) - Method in class com.hazelcast.client.txn.proxy.ClientTxnMapProxy
-  
- getForUpdate(Object) - Method in interface com.hazelcast.core.TransactionalMap
- 
Locks the key and then gets and returns the value to which the specified key is mapped. 
- getForUpdate(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-  
- getForUpdateInternal(Data) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-  
- getFrameLength() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
- 
Returns the frame length field. 
- getFreeHeap() - Method in class com.hazelcast.memory.DefaultMemoryStats
-  
- getFreeHeap() - Method in interface com.hazelcast.memory.MemoryStats
- 
Returns the amount of free memory in the JVM in bytes. 
- getFreeHeap() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- getFreeMemory() - Method in class com.hazelcast.map.impl.eviction.EvictionCheckerImpl
-  
- getFreeMemory() - Method in interface com.hazelcast.util.MemoryInfoAccessor
- 
Returns the amount of free memory in the Java virtual machine in bytes. 
- getFreeMemory() - Method in class com.hazelcast.util.RuntimeMemoryInfoAccessor
-  
- getFreeNativeMemory() - Method in class com.hazelcast.memory.DefaultMemoryStats
-  
- getFreeNativeMemory() - Method in interface com.hazelcast.memory.MemoryStats
- 
Returns the amount of free native memory in current HazelcastInstance in bytes. 
- getFreeNativeMemory() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- getFreePhysical() - Method in class com.hazelcast.memory.DefaultMemoryStats
-  
- getFreePhysical() - Method in interface com.hazelcast.memory.MemoryStats
- 
Returns free physical memory available in OS. 
- getFreePhysical() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- getFromNearCache(String, Data) - Method in class com.hazelcast.map.impl.nearcache.NearCacheProvider
-  
- getFrontByNumber(int, Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
- 
Adds the given number of elements to the supplied collection by starting from the head of this queue. 
- getFrontByTime(long, Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
- 
Adds all elements to the supplied collection which are smaller than or equal to the given time. 
- getFunction() - Method in class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
-  
- getFuture() - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-  
- getFuture() - Method in class com.hazelcast.util.executor.DelegatingFuture
-  
- getGCStats() - Method in class com.hazelcast.memory.DefaultMemoryStats
-  
- getGCStats() - Static method in class com.hazelcast.memory.GCStatsSupport
-  
- getGCStats() - Method in interface com.hazelcast.memory.MemoryStats
- 
Returns the garbage collector statistics for the JVM 
- getGCStats() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- getGCStats() - Method in interface com.hazelcast.monitor.LocalMemoryStats
-  
- getGenericOperationRunners() - Method in class com.hazelcast.spi.impl.operationexecutor.classic.ClassicOperationExecutor
-  
- getGenericOperationRunners() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
- 
Gets all the generic operation handlers. 
- getGenericOperationThreadCount() - Method in class com.hazelcast.spi.impl.operationexecutor.classic.ClassicOperationExecutor
-  
- getGenericOperationThreadCount() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
- 
Deprecated. 
- getGenericOperationThreadCount() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- getGenericOperationThreadCount() - Method in interface com.hazelcast.spi.OperationService
- 
Deprecated. 
- getGetHits() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- getGetMisses() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- getGetOperationCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getGetOperationCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getGetOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns the number of get operations 
- getGlobalSerializerConfig() - Method in class com.hazelcast.config.SerializationConfig
-  
- getGlobalTransactionId() - Method in class com.hazelcast.transaction.impl.xa.SerializableXID
-  
- getGroupConfig() - Method in class com.hazelcast.client.config.ClientConfig
- 
- getGroupConfig() - Method in class com.hazelcast.config.Config
-  
- getGroupName() - Method in interface com.hazelcast.client.spi.ClientTransactionManagerService
-  
- getGroupName() - Method in class com.hazelcast.client.spi.impl.ClientTransactionManagerServiceImpl
-  
- getGroupName() - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- getGroupName() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getGroupName() - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-  
- getGroupName() - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
-  
- getGroupPassword() - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- getGroupProperties() - Method in class com.hazelcast.instance.Node
-  
- getGroupProperties() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getGroupProperties() - Method in interface com.hazelcast.spi.NodeEngine
- 
Returns the GroupProperties. 
- getGroupType() - Method in class com.hazelcast.config.PartitionGroupConfig
- 
Returns the MemberGroupType configured. 
- getHandler() - Method in class com.hazelcast.client.spi.impl.listener.ClientRegistrationKey
-  
- getHazelcastClientByName(String) - Static method in class com.hazelcast.client.HazelcastClient
- 
Returns an existing HazelcastClient with instanceName. 
- getHazelcastInstance() - Method in interface com.hazelcast.cache.HazelcastCacheManager
- 
- getHazelcastInstance() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- getHazelcastInstance() - Method in class com.hazelcast.client.spi.ClientContext
-  
- getHazelcastInstance() - Method in class com.hazelcast.client.spi.ProxyManager
-  
- getHazelcastInstance() - Method in class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
-  
- getHazelcastInstance(Session) - Static method in class com.hazelcast.hibernate.instance.HazelcastAccessor
- 
Deprecated. Tries to extract HazelcastInstancefromSession.
 
- getHazelcastInstance(SessionFactory) - Static method in class com.hazelcast.hibernate.instance.HazelcastAccessor
- 
Deprecated. Tries to extract HazelcastInstancefromSessionFactory.
 
- getHazelcastInstance(SessionFactoryImplementor) - Static method in class com.hazelcast.hibernate.instance.HazelcastAccessor
- 
Deprecated. Tries to extract HazelcastInstancefromSessionFactoryImplementor.
 
- getHazelcastInstance(String) - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
-  
- getHazelcastInstance() - Method in class com.hazelcast.internal.management.ManagementCenterService
-  
- getHazelcastInstance() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getHazelcastInstance() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getHazelcastInstance() - Method in interface com.hazelcast.spi.NodeEngine
- 
Returns the HazelcastInstance that this  NodeEngine belongs to. 
- getHazelcastInstance() - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
-  
- getHazelcastInstanceByName(String) - Static method in class com.hazelcast.core.Hazelcast
- 
Returns an existing HazelcastInstance with instanceName. 
- getHazelcastInstanceByName(String) - Method in interface com.hazelcast.osgi.HazelcastOSGiService
- 
- getHazelcastRegion() - Method in class com.hazelcast.hibernate.access.AbstractAccessDelegate
-  
- getHazelcastRegion() - Method in interface com.hazelcast.hibernate.access.AccessDelegate
- 
Get the wrapped cache region 
- getHazelcastThreadGroup() - Method in class com.hazelcast.instance.Node
-  
- getHeader() - Method in class com.hazelcast.nio.Packet
- 
Returns the header of the Packet. 
- getHeadSeq() - Method in exception com.hazelcast.ringbuffer.StaleSequenceException
- 
Returns the last known head sequence. 
- getHeapCost() - Method in class com.hazelcast.internal.serialization.impl.HeapData
-  
- getHeapCost() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- getHeapCost() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getHeapCost() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getHeapCost() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Cost of map & near cache  & backup in bytes
 todo in object mode object size is zero. 
- getHeapCost() - Method in interface com.hazelcast.nio.serialization.Data
- 
Returns approximate heap cost of this Data object in bytes. 
- getHeartBeatInterval() - Method in class com.hazelcast.client.spi.impl.ClientInvocation
-  
- getHits() - Method in interface com.hazelcast.core.EntryView
- 
Returns number of hits of the entry. 
- getHits(Record) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
-  
- getHits() - Method in class com.hazelcast.map.impl.record.EmptyRecordStatistics
-  
- getHits() - Method in interface com.hazelcast.map.impl.record.RecordStatistics
-  
- getHits() - Method in class com.hazelcast.map.impl.record.RecordStatisticsImpl
-  
- getHits() - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- getHits() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getHits() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getHits() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-  
- getHits() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns the number of hits (reads) of the locally owned entries. 
- getHits() - Method in interface com.hazelcast.monitor.NearCacheStats
- 
Returns the number of hits (reads) of the locally owned entries. 
- getHits() - Method in class com.hazelcast.multimap.impl.MultiMapValue
-  
- getHits() - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
-  
- getHits() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- getHits() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-  
- getHost() - Method in class com.hazelcast.nio.Address
-  
- getHostHeader() - Method in class com.hazelcast.config.AwsConfig
- 
Gets the host header; the address where the EC2 API can be found. 
- getHotRestartConfig() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Gets the HotRestartConfigfor thisCacheSimpleConfig
 
- getHotRestartConfig() - Method in class com.hazelcast.config.MapConfig
- 
Gets the HotRestartConfigfor thisMapConfig
 
- getHotRestartPersistenceConfig() - Method in class com.hazelcast.config.Config
- 
Returns hot restart configuration for this member 
- getIamRole() - Method in class com.hazelcast.config.AwsConfig
- 
Gets the iamRole name 
- getId() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-  
- getId() - Method in class com.hazelcast.cache.impl.CacheClearResponse
-  
- getId() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-  
- getId() - Method in class com.hazelcast.cache.impl.CacheEventSet
-  
- getId() - Method in class com.hazelcast.cache.impl.CacheKeyIteratorResult
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheContainsKeyOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheDestroyOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheGetOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheKeyIteratorOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CachePutBackupOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperation
-  
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
-  
- getId() - Method in class com.hazelcast.client.impl.client.ClientResponse
-  
- getId() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getId() - Method in enum com.hazelcast.client.impl.protocol.AuthenticationStatus
-  
- getId() - Method in class com.hazelcast.client.spi.ClientProxy
- 
Deprecated. 
- getId() - Method in class com.hazelcast.cluster.client.ClientInitialMembershipEvent
-  
- getId() - Method in class com.hazelcast.cluster.client.ClientMembershipEvent
-  
- getId() - Method in class com.hazelcast.cluster.impl.BindMessage
-  
- getId() - Method in class com.hazelcast.cluster.impl.ConfigCheck
-  
- getId() - Method in class com.hazelcast.cluster.impl.operations.FinalizeJoinOperation
-  
- getId() - Method in class com.hazelcast.cluster.impl.operations.HeartbeatOperation
-  
- getId() - Method in class com.hazelcast.cluster.impl.operations.MemberInfoUpdateOperation
-  
- getId() - Method in enum com.hazelcast.cluster.MemberAttributeOperationType
-  
- getId() - Method in class com.hazelcast.collection.impl.collection.CollectionEvent
-  
- getId() - Method in class com.hazelcast.collection.impl.collection.CollectionEventFilter
-  
- getId() - Method in class com.hazelcast.collection.impl.collection.CollectionItem
-  
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionClearBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionClearOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionCompareAndRemoveOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionContainsOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionGetAllOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionIsEmptyOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionSizeOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.collection.TxCollectionItem
-  
- getId() - Method in class com.hazelcast.collection.impl.list.operations.ListAddAllOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.list.operations.ListAddOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.list.operations.ListGetOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.list.operations.ListIndexOfOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.list.operations.ListRemoveOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.list.operations.ListReplicationOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.list.operations.ListSetBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.list.operations.ListSetOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.list.operations.ListSubOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.AddAllBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.AddAllOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.CheckAndEvictOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.ClearBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.ClearOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.ContainsOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.DrainBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.DrainOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.IsEmptyOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.IteratorOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.OfferBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.PeekOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.PollBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.QueueReplicationOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.RemainingCapacityOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.RemoveBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.RemoveOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.operations.SizeOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.QueueEvent
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.QueueEventFilter
-  
- getId() - Method in class com.hazelcast.collection.impl.queue.QueueItem
-  
- getId() - Method in class com.hazelcast.collection.impl.set.operations.SetReplicationOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveAddOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveRemoveOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTransactionRollbackOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.QueueTransactionRollbackOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPeekOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackBackupOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackOperation
-  
- getId() - Method in class com.hazelcast.collection.impl.txnqueue.TxQueueItem
-  
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AlterAndGetOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AlterOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAlterOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.SetBackupOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.SetOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.AlterAndGetOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.AlterOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndAlterOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.IsNullOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetBackupOperation
-  
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetOperation
-  
- getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
-  
- getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
-  
- getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
-  
- getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
-  
- getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.GetCountOperation
-  
- getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
-  
- getId() - Method in class com.hazelcast.concurrent.lock.operations.AwaitBackupOperation
-  
- getId() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
-  
- getId() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitBackupOperation
-  
- getId() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
-  
- getId() - Method in class com.hazelcast.concurrent.lock.operations.GetLockCountOperation
-  
- getId() - Method in class com.hazelcast.concurrent.lock.operations.GetRemainingLeaseTimeOperation
-  
- getId() - Method in class com.hazelcast.concurrent.lock.operations.IsLockedOperation
-  
- getId() - Method in class com.hazelcast.concurrent.lock.operations.LockBackupOperation
-  
- getId() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
-  
- getId() - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
-  
- getId() - Method in class com.hazelcast.concurrent.lock.operations.SignalBackupOperation
-  
- getId() - Method in class com.hazelcast.concurrent.lock.operations.SignalOperation
-  
- getId() - Method in class com.hazelcast.concurrent.lock.operations.UnlockBackupOperation
-  
- getId() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
-  
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireBackupOperation
-  
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
-  
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.AvailableOperation
-  
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.DeadMemberBackupOperation
-  
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainBackupOperation
-  
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainOperation
-  
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.InitBackupOperation
-  
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.InitOperation
-  
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceBackupOperation
-  
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
-  
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseBackupOperation
-  
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
-  
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-  
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
-  
- getId() - Method in enum com.hazelcast.config.WanAcknowledgeType
- 
- getId() - Method in enum com.hazelcast.config.WANQueueFullBehavior
- 
- getId() - Method in class com.hazelcast.executor.impl.operations.CallableTaskOperation
-  
- getId() - Method in class com.hazelcast.executor.impl.operations.MemberCallableTaskOperation
-  
- getId() - Method in class com.hazelcast.executor.impl.RunnableAdapter
-  
- getId() - Method in class com.hazelcast.hibernate.distributed.LockEntryProcessor
-  
- getId() - Method in class com.hazelcast.hibernate.distributed.UnlockEntryProcessor
-  
- getId() - Method in class com.hazelcast.hibernate.distributed.UpdateEntryProcessor
-  
- getId() - Method in class com.hazelcast.hibernate.local.Invalidation
-  
- getId() - Method in class com.hazelcast.hibernate.local.Timestamp
-  
- getId() - Method in class com.hazelcast.hibernate.serialization.ExpiryMarker
-  
- getId() - Method in class com.hazelcast.hibernate.serialization.Value
-  
- getId() - Method in class com.hazelcast.instance.MemberImpl
-  
- getId() - Method in class com.hazelcast.map.impl.MapEntries
-  
- getId() - Method in class com.hazelcast.map.impl.MapKeySet
-  
- getId() - Method in class com.hazelcast.map.impl.MapValueCollection
-  
- getId() - Method in class com.hazelcast.map.impl.operation.GetOperation
-  
- getId() - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
-  
- getId() - Method in class com.hazelcast.map.impl.operation.PutOperation
-  
- getId() - Method in class com.hazelcast.map.impl.operation.RemoveBackupOperation
-  
- getId() - Method in class com.hazelcast.map.impl.operation.RemoveOperation
-  
- getId() - Method in class com.hazelcast.map.impl.query.QueryResult
-  
- getId() - Method in class com.hazelcast.map.impl.query.QueryResultRow
-  
- getId() - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- getId() - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
-  
- getId() - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
-  
- getId() - Method in class com.hazelcast.mapreduce.aggregation.impl.AcceptAllSupplier
-  
- getId() - Method in class com.hazelcast.mapreduce.aggregation.impl.AvgTuple
-  
- getId() - Method in class com.hazelcast.mapreduce.aggregation.impl.KeyPredicateSupplier
-  
- getId() - Method in class com.hazelcast.mapreduce.aggregation.impl.PredicateSupplier
-  
- getId() - Method in class com.hazelcast.mapreduce.aggregation.impl.SetAdapter
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.CombinerResultList
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.HashMapAdapter
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.ListKeyValueSource
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.MapKeyValueSource
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.MultiMapKeyValueSource
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.notification.IntermediateChunkNotification
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.notification.LastChunkNotification
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.notification.ReducingFinishedNotification
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.CancelJobSupervisorOperation
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.FireNotificationOperation
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.GetResultOperation
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentOperation
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentResult
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.KeyValueJobOperation
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.NotifyRemoteExceptionOperation
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.PostPonePartitionProcessing
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.ProcessStatsUpdateOperation
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestMemberIdAssignment
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionMapping
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionProcessed
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionReducing
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionResult
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.StartProcessingJobOperation
-  
- getId() - Method in class com.hazelcast.mapreduce.impl.SetKeyValueSource
-  
- getId() - Method in class com.hazelcast.multimap.impl.operations.ClearBackupOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.operations.ClearOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.operations.CountOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.operations.EntrySetOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.operations.GetAllOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.operations.KeySetOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.operations.PutBackupOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.operations.PutOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllBackupOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.operations.RemoveBackupOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.operations.RemoveOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.operations.SizeOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.operations.ValuesOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitBackupOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnGenerateRecordIdOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareBackupOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnPutBackupOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllBackupOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveBackupOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackBackupOperation
-  
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackOperation
-  
- getId() - Method in class com.hazelcast.nio.Address
-  
- getId() - Method in enum com.hazelcast.nio.serialization.FieldType
-  
- getId() - Method in interface com.hazelcast.nio.serialization.IdentifiedDataSerializable
- 
Returns type identifier for this class. 
- getId() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
- 
Gets the id of service. 
- getId() - Method in class com.hazelcast.partition.client.PartitionsResponse
-  
- getId() - Method in class com.hazelcast.partition.PartitionRuntimeState
-  
- getId() - Method in class com.hazelcast.query.impl.FalsePredicate
-  
- getId() - Method in class com.hazelcast.query.impl.predicates.AndPredicate
-  
- getId() - Method in class com.hazelcast.query.impl.predicates.BetweenPredicate
-  
- getId() - Method in class com.hazelcast.query.impl.predicates.EqualPredicate
-  
- getId() - Method in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
-  
- getId() - Method in class com.hazelcast.query.impl.predicates.ILikePredicate
-  
- getId() - Method in class com.hazelcast.query.impl.predicates.InPredicate
-  
- getId() - Method in class com.hazelcast.query.impl.predicates.InstanceOfPredicate
-  
- getId() - Method in class com.hazelcast.query.impl.predicates.LikePredicate
-  
- getId() - Method in class com.hazelcast.query.impl.predicates.NotEqualPredicate
-  
- getId() - Method in class com.hazelcast.query.impl.predicates.NotPredicate
-  
- getId() - Method in class com.hazelcast.query.impl.predicates.OrPredicate
-  
- getId() - Method in class com.hazelcast.query.impl.predicates.RegexPredicate
-  
- getId() - Method in class com.hazelcast.query.PagingPredicate
-  
- getId() - Method in class com.hazelcast.query.SqlPredicate
-  
- getId() - Method in class com.hazelcast.query.TruePredicate
-  
- getId() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperation
-  
- getId() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- getId() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllBackupOperation
-  
- getId() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
-  
- getId() - Method in class com.hazelcast.ringbuffer.impl.operations.AddBackupOperation
-  
- getId() - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
-  
- getId() - Method in class com.hazelcast.ringbuffer.impl.operations.GenericOperation
-  
- getId() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadManyOperation
-  
- getId() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadOneOperation
-  
- getId() - Method in class com.hazelcast.ringbuffer.impl.operations.ReplicationOperation
-  
- getId() - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
-  
- getId() - Method in enum com.hazelcast.ringbuffer.OverflowPolicy
- 
Gets the id for the given OverflowPolicy. 
- getId() - Method in interface com.hazelcast.spi.EventRegistration
- 
Returns the event registration id. 
- getId() - Method in class com.hazelcast.spi.impl.BinaryOperationFactory
-  
- getId() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventEnvelope
-  
- getId() - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
-  
- getId() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
-  
- getId() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation
-  
- getId() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation.PartitionResponse
-  
- getId() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.BackupResponse
-  
- getId() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.CallTimeoutResponse
-  
- getId() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.ErrorResponse
-  
- getId() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.NormalResponse
-  
- getId() - Method in class com.hazelcast.spi.impl.SerializableList
-  
- getId() - Method in class com.hazelcast.topic.impl.PublishOperation
-  
- getId() - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicMessage
-  
- getId() - Method in class com.hazelcast.topic.impl.TopicEvent
-  
- getId() - Method in class com.hazelcast.transaction.impl.operations.BroadcastTxRollbackOperation
-  
- getId() - Method in class com.hazelcast.transaction.impl.operations.CreateAllowedDuringPassiveStateTxBackupLogOperation
-  
- getId() - Method in class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
-  
- getId() - Method in class com.hazelcast.transaction.impl.operations.PurgeAllowedDuringPassiveStateTxBackupLogOperation
-  
- getId() - Method in class com.hazelcast.transaction.impl.operations.PurgeTxBackupLogOperation
-  
- getId() - Method in class com.hazelcast.transaction.impl.operations.ReplicateAllowedDuringPassiveStateTxBackupLogOperation
-  
- getId() - Method in class com.hazelcast.transaction.impl.operations.ReplicateTxBackupLogOperation
-  
- getId() - Method in class com.hazelcast.transaction.impl.operations.RollbackAllowedDuringPassiveStateTxBackupLogOperation
-  
- getId() - Method in class com.hazelcast.transaction.impl.operations.RollbackTxBackupLogOperation
-  
- getId() - Method in enum com.hazelcast.util.IterationType
- 
Gets the id for the given IterationType. 
- getId() - Method in class com.hazelcast.wan.WanReplicationEvent
-  
- getId() - Method in class com.hazelcast.web.entryprocessor.DeleteSessionEntryProcessor
-  
- getId() - Method in class com.hazelcast.web.entryprocessor.GetAttributeEntryProcessor
-  
- getId() - Method in class com.hazelcast.web.entryprocessor.GetAttributeNamesEntryProcessor
-  
- getId() - Method in class com.hazelcast.web.entryprocessor.GetSessionStateEntryProcessor
-  
- getId() - Method in class com.hazelcast.web.entryprocessor.SessionUpdateEntryProcessor
-  
- getId() - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- getId() - Method in class com.hazelcast.web.SessionState
-  
- getId2InterceptorMap() - Method in class com.hazelcast.map.impl.InterceptorRegistry
-  
- getIdGenerator(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getIdGenerator(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getIdGenerator(String) - Method in interface com.hazelcast.core.HazelcastInstance
- 
Creates cluster-wide unique IDs. 
- getIdGenerator(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getIdGenerator(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getIdGenerator(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getIdlenessStartTime(Record) - Static method in class com.hazelcast.map.impl.ExpirationTimeSetter
- 
Returns last-access-time of an entry if it was accessed before, otherwise it returns creation-time of the entry. 
- getImpl() - Method in class com.hazelcast.map.impl.MapStoreWrapper
-  
- getImplementation() - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
-  
- getImplementation() - Method in class com.hazelcast.config.CachePartitionLostListenerConfigReadOnly
-  
- getImplementation() - Method in class com.hazelcast.config.CredentialsFactoryConfig
-  
- getImplementation() - Method in class com.hazelcast.config.EntryListenerConfig
-  
- getImplementation() - Method in class com.hazelcast.config.GlobalSerializerConfig
-  
- getImplementation() - Method in class com.hazelcast.config.ItemListenerConfig
-  
- getImplementation() - Method in class com.hazelcast.config.ListenerConfig
- 
Returns the EventListener implementation. 
- getImplementation() - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
-  
- getImplementation() - Method in class com.hazelcast.config.MapPartitionLostListenerConfigReadOnly
-  
- getImplementation() - Method in class com.hazelcast.config.MapStoreConfig
- 
Returns the map store implementation object. 
- getImplementation() - Method in class com.hazelcast.config.PermissionPolicyConfig
-  
- getImplementation() - Method in class com.hazelcast.config.PredicateConfig
- 
Returns the Predicate implementation. 
- getImplementation() - Method in class com.hazelcast.config.QuorumListenerConfig
-  
- getImplementation() - Method in class com.hazelcast.config.SecurityInterceptorConfig
-  
- getImplementation() - Method in class com.hazelcast.config.SerializerConfig
- 
Returns the implementation of the serializer class. 
- getImplementation() - Method in class com.hazelcast.config.SocketInterceptorConfig
- 
- getImplementationClass() - Method in enum com.hazelcast.cache.BuiltInCacheMergePolicies
-  
- getImplementationClassName() - Method in enum com.hazelcast.cache.BuiltInCacheMergePolicies
- 
- getImplementationName() - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-  
- getImplementationVendor() - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-  
- getImplementationVersion() - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-  
- getIn() - Method in class com.hazelcast.client.config.XmlClientConfigLocator
-  
- getIn() - Method in class com.hazelcast.config.XmlConfigLocator
-  
- getIncrHits() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- getIncrMisses() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- getIndex() - Method in enum com.hazelcast.client.config.ClientProperty
-  
- getIndex() - Method in enum com.hazelcast.instance.GroupProperty
-  
- getIndex() - Method in interface com.hazelcast.instance.HazelcastProperty
- 
Gets the index of the property. 
- getIndex() - Method in class com.hazelcast.internal.serialization.impl.FieldDefinitionImpl
-  
- getIndex() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
-  
- getIndex(String) - Method in class com.hazelcast.query.impl.Indexes
- 
Get index for a given attribute. 
- getIndex(QueryContext) - Method in class com.hazelcast.query.impl.predicates.AbstractIndexAwarePredicate
-  
- getIndex(String) - Method in class com.hazelcast.query.impl.QueryContext
-  
- getIndexConfigs() - Method in class com.hazelcast.config.QueryCacheConfig
-  
- getIndexes() - Method in class com.hazelcast.map.impl.MapContainer
-  
- getIndexes() - Method in class com.hazelcast.query.impl.Indexes
-  
- getInetAddress() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- getInetAddress() - Method in class com.hazelcast.instance.AbstractMember
-  
- getInetAddress() - Method in class com.hazelcast.nio.Address
-  
- getInetAddress() - Method in interface com.hazelcast.nio.Connection
- 
Returns remote address of this Connection. 
- getInetAddress() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- getInetAddressFor(Inet6Address, String) - Static method in class com.hazelcast.util.AddressUtil
-  
- getInetSocketAddress() - Method in interface com.hazelcast.core.Member
- 
- getInetSocketAddress() - Method in class com.hazelcast.instance.AbstractMember
-  
- getInetSocketAddress() - Method in class com.hazelcast.nio.Address
-  
- getInitialLoadMode() - Method in class com.hazelcast.config.MapStoreConfig
- 
Returns the initial load mode 
- getInitialPermits() - Method in class com.hazelcast.config.SemaphoreConfig
- 
Gets the initial number of permits. 
- getInMemoryFormat() - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache
-  
- getInMemoryFormat() - Method in interface com.hazelcast.cache.impl.nearcache.NearCache
- 
- getInMemoryFormat() - Method in class com.hazelcast.client.map.impl.nearcache.ClientHeapNearCache
-  
- getInMemoryFormat() - Method in class com.hazelcast.config.CacheConfig
- 
Gets the data type that will be used to store records. 
- getInMemoryFormat() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Gets the InMemory Format for this  ICache. 
- getInMemoryFormat() - Method in class com.hazelcast.config.MapConfig
- 
Returns the data type that will be used for storing records. 
- getInMemoryFormat() - Method in class com.hazelcast.config.NearCacheConfig
- 
Gets the data type used to store entries. 
- getInMemoryFormat() - Method in class com.hazelcast.config.QueryCacheConfig
- 
Returns memory format of values of entries in QueryCache.
 
- getInMemoryFormat() - Method in class com.hazelcast.config.ReplicatedMapConfig
- 
Data type used to store entries. 
- getInMemoryFormat() - Method in class com.hazelcast.config.RingbufferConfig
- 
Gets the InMemoryFormat. 
- getInMemoryFormat() - Method in class com.hazelcast.map.impl.nearcache.NearCacheImpl
-  
- getInputSelectorThreadCount() - Method in interface com.hazelcast.nio.IOService
-  
- getInputSelectorThreadCount() - Method in class com.hazelcast.nio.NodeIOService
-  
- getInputThreads() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingIOThreadingModel
-  
- getInstance() - Method in interface com.hazelcast.hibernate.region.HazelcastRegion
-  
- getInstanceMBean() - Method in class com.hazelcast.jmx.ManagementService
-  
- getInstanceName() - Method in class com.hazelcast.client.config.ClientConfig
-  
- getInstanceName() - Method in class com.hazelcast.config.Config
-  
- getInstanceName(Properties) - Static method in class com.hazelcast.hibernate.CacheEnvironment
-  
- getInstanceNames() - Method in class com.hazelcast.monitor.TimedMemberState
-  
- getInt(int) - Method in interface com.hazelcast.client.impl.protocol.util.ClientProtocolBuffer
- 
Get the value at a given index. 
- getInt() - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- getInt(int) - Method in class com.hazelcast.client.impl.protocol.util.SafeBuffer
-  
- getInt(int) - Method in class com.hazelcast.client.impl.protocol.util.UnsafeBuffer
-  
- getInt(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
- 
Returns a field in a Json object as an int. 
- getInt(JsonObject, String, int) - Static method in class com.hazelcast.util.JsonUtil
- 
Returns a field in a Json object as an int. 
- getInt(int) - Static method in class com.hazelcast.util.RandomPicker
- 
Returns a pseudorandom, uniformly distributed int value between 0 (inclusive)
 and the specified value (exclusive), drawn from this random number generator's sequence. 
- getInt(int, int) - Static method in class com.hazelcast.util.RandomPicker
- 
Return a pseudorandom, uniformly distributed in value between the low value (inclusive) and
 the high value (exclusive), drawn from this random number generator's sequence. 
- getIntAttribute(String) - Method in class com.hazelcast.client.impl.MemberImpl
-  
- getIntAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-  
- getIntAttribute(String) - Method in interface com.hazelcast.core.Member
- 
Returns the value of the specified key for this member or
 null if value is undefined. 
- getIntAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-  
- getInteger(HazelcastProperty) - Method in class com.hazelcast.instance.HazelcastProperties
- 
- getIntegerValue(String, String) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
-  
- getInterceptorRegistry() - Method in class com.hazelcast.map.impl.MapContainer
-  
- getInterceptors() - Method in class com.hazelcast.map.impl.InterceptorRegistry
- 
Returns all registered interceptors. 
- getInterfaces() - Method in class com.hazelcast.config.InterfacesConfig
-  
- getInterfaces() - Method in class com.hazelcast.config.MemberGroupConfig
- 
Gets an unmodifiable collection containing all interfaces. 
- getInterfaces() - Method in class com.hazelcast.config.NetworkConfig
-  
- getInternal(Data) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- getInternal(Data) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- getInternal(Data) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- getInternal(Data) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-  
- getInternal(Data) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-  
- getInternalExecutor() - Method in class com.hazelcast.client.spi.impl.ClientExecutionServiceImpl
-  
- getInternalThreadGroup() - Method in class com.hazelcast.instance.HazelcastThreadGroup
- 
Gets the internal ThreadGroup; so the actual ThreadGroup object. 
- getInvalidationListenerCount() - Method in class com.hazelcast.cache.impl.CacheContext
-  
- getInvalidationMessages() - Method in class com.hazelcast.cache.impl.client.CacheBatchInvalidationMessage
-  
- getInvalidations() - Method in class com.hazelcast.map.impl.nearcache.BatchNearCacheInvalidation
-  
- getInvocation() - Method in class com.hazelcast.client.spi.impl.ClientInvocationFuture
-  
- getInvocationBuilder(Operation) - Method in class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
-  
- getInvocationBuilder(Operation) - Method in class com.hazelcast.cache.impl.client.CacheManagementConfigRequest
-  
- getInvocationBuilder(Operation) - Method in class com.hazelcast.client.impl.client.ClientCreateRequest
-  
- getInvocationBuilder(Operation) - Method in class com.hazelcast.client.impl.client.TargetClientRequest
-  
- getInvocationBuilder(Operation) - Method in class com.hazelcast.client.impl.protocol.task.AbstractInvocationMessageTask
-  
- getInvocationBuilder(Operation) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
-  
- getInvocationBuilder(Operation) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
-  
- getInvocationBuilder(Operation) - Method in class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
-  
- getInvocationBuilder(Operation) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
-  
- getInvocationBuilder(Operation) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
-  
- getInvocationBuilder(Operation) - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearNearCacheMessageTask
-  
- getInvocationBuilder(Operation) - Method in class com.hazelcast.executor.impl.client.PartitionTargetCallableRequest
-  
- getInvocationBuilder(Operation) - Method in class com.hazelcast.executor.impl.client.SpecificTargetCallableRequest
-  
- getInvocationBuilder(Operation) - Method in class com.hazelcast.map.impl.client.MapClearNearCacheRequest
-  
- getInvocationService() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getInvocationService() - Method in class com.hazelcast.client.spi.ClientContext
-  
- getInvocationsRegistry() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- getInvocationTime() - Method in class com.hazelcast.spi.Operation
- 
Gets the time in milliseconds since this invocation started. 
- getIOBalancer() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingIOThreadingModel
-  
- getIoBalancer() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- getIoExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getIoService() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- getIoThreadingModel() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- getIsStillRunningService() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- getItem() - Method in class com.hazelcast.collection.common.DataAwareItemEvent
-  
- getItem() - Method in class com.hazelcast.core.ItemEvent
- 
Returns the item related to the event. 
- getItem() - Method in class com.hazelcast.spi.impl.PortableItemEvent
-  
- getItemAtPositionOrNull(T[], int) - Static method in class com.hazelcast.util.collection.ArrayUtils
-  
- getItemAtPositionOrNull(Collection<T>, int) - Static method in class com.hazelcast.util.CollectionUtil
- 
Return n-th item or null if collection is smaller 
- getItemData() - Method in class com.hazelcast.collection.common.DataAwareItemEvent
-  
- getItemId() - Method in class com.hazelcast.collection.impl.collection.CollectionItem
-  
- getItemId() - Method in class com.hazelcast.collection.impl.queue.QueueItem
-  
- getItemListenerConfigs() - Method in class com.hazelcast.config.CollectionConfig
- 
Gets the list of ItemListenerConfigs. 
- getItemListenerConfigs() - Method in class com.hazelcast.config.ListConfigReadOnly
-  
- getItemListenerConfigs() - Method in class com.hazelcast.config.QueueConfig
- 
Get the list of item listener configurations for this queue. 
- getItemListenerConfigs() - Method in class com.hazelcast.config.QueueConfigReadOnly
-  
- getItemListenerConfigs() - Method in class com.hazelcast.config.SetConfigReadOnly
-  
- getItemQueue() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- getIterationCount() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-  
- getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapQueryMessageTask
-  
- getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPagingPredicateMessageTask
-  
- getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPredicateMessageTask
-  
- getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntrySetMessageTask
-  
- getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
-  
- getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPagingPredicateMessageTask
-  
- getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
-  
- getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesMessageTask
-  
- getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPagingPredicateMessageTask
-  
- getIterationType() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPredicateMessageTask
-  
- getIterationType() - Method in class com.hazelcast.map.impl.query.QueryResultCollection
-  
- getIterationType() - Method in class com.hazelcast.query.PagingPredicate
-  
- getJobId() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.AbstractMapReduceTask
-  
- getJobId() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForCustomMessageTask
-  
- getJobId() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForListMessageTask
-  
- getJobId() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMapMessageTask
-  
- getJobId() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMultiMapMessageTask
-  
- getJobId() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForSetMessageTask
-  
- getJobId() - Method in class com.hazelcast.mapreduce.impl.notification.MapReduceNotification
-  
- getJobId() - Method in class com.hazelcast.mapreduce.impl.operation.ProcessingOperation
-  
- getJobId() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-  
- getJobId() - Method in class com.hazelcast.mapreduce.impl.task.MapCombineTask
-  
- getJobId() - Method in class com.hazelcast.mapreduce.impl.task.ReducerTask
-  
- getJobId() - Method in class com.hazelcast.mapreduce.impl.task.TrackableJobFuture
-  
- getJobId() - Method in interface com.hazelcast.mapreduce.JobCompletableFuture
- 
Returns the unique identifier for this mapreduce job. 
- getJobId() - Method in interface com.hazelcast.mapreduce.TrackableJob
- 
Returns the unique job id of the tracked job 
- getJobOwner() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-  
- getJobOwner() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-  
- getJobProcessInformation() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-  
- getJobProcessInformation() - Method in class com.hazelcast.mapreduce.impl.task.TrackableJobFuture
-  
- getJobProcessInformation() - Method in interface com.hazelcast.mapreduce.TrackableJob
- 
Returns an instance of  JobProcessInformation to find out the state and
 statistics of a running task, or returns null if the underlying job id is not available because the job is already
 finished or has not yet been submitted. 
 It returns null if not requested on the job issuing cluster member or client, since those values are
 not distributed to all clusters for traffic reasons. 
- getJobResults() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-  
- getJobSupervisor(String, String) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-  
- getJobTracker(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getJobTracker(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getJobTracker(String) - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the job tracker instance with the specified name. 
- getJobTracker(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getJobTracker(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getJobTracker(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getJobTracker(String) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-  
- getJobTracker() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-  
- getJobTracker() - Method in class com.hazelcast.mapreduce.impl.task.TrackableJobFuture
-  
- getJobTracker() - Method in interface com.hazelcast.mapreduce.TrackableJob
- 
- getJobTrackerConfig(String) - Method in class com.hazelcast.config.Config
-  
- getJobTrackerConfig() - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-  
- getJobTrackerConfigs() - Method in class com.hazelcast.config.Config
-  
- getJoin() - Method in class com.hazelcast.config.NetworkConfig
- 
- getJoiner() - Method in class com.hazelcast.instance.Node
-  
- getKey() - Method in interface com.hazelcast.cache.CacheEntryView
- 
Gets the key of the cache entry. 
- getKey() - Method in class com.hazelcast.cache.impl.CacheEntry
-  
- getKey() - Method in class com.hazelcast.cache.impl.CacheEntryEventImpl
-  
- getKey() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-  
- getKey(int) - Method in class com.hazelcast.cache.impl.CacheKeyIteratorResult
-  
- getKey() - Method in class com.hazelcast.cache.impl.client.CacheContainsKeyRequest
-  
- getKey() - Method in class com.hazelcast.cache.impl.client.CacheEntryProcessorRequest
-  
- getKey() - Method in class com.hazelcast.cache.impl.client.CacheGetAndRemoveRequest
-  
- getKey() - Method in class com.hazelcast.cache.impl.client.CacheGetAndReplaceRequest
-  
- getKey() - Method in class com.hazelcast.cache.impl.client.CacheGetConfigRequest
-  
- getKey() - Method in class com.hazelcast.cache.impl.client.CacheGetRequest
-  
- getKey() - Method in class com.hazelcast.cache.impl.client.CacheInvalidationMessage
-  
- getKey() - Method in class com.hazelcast.cache.impl.client.CachePutIfAbsentRequest
-  
- getKey() - Method in class com.hazelcast.cache.impl.client.CachePutRequest
-  
- getKey() - Method in class com.hazelcast.cache.impl.client.CacheRemoveRequest
-  
- getKey() - Method in class com.hazelcast.cache.impl.client.CacheReplaceRequest
-  
- getKey() - Method in class com.hazelcast.cache.impl.client.CacheSingleInvalidationMessage
-  
- getKey() - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
-  
- getKey() - Method in class com.hazelcast.cache.impl.merge.entry.LazyCacheEntryView
-  
- getKey() - Method in class com.hazelcast.client.impl.client.KeyBasedClientRequest
-  
- getKey() - Method in class com.hazelcast.client.impl.protocol.task.multimap.AbstractMultiMapAddEntryListenerMessageTask
-  
- getKey() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerToKeyMessageTask
-  
- getKey() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
-  
- getKey() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerMessageTask
-  
- getKey() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyMessageTask
-  
- getKey() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask
-  
- getKey() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerWithPredicateMessageTask
-  
- getKey() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddNearCacheListenerMessageTask
-  
- getKey() - Method in class com.hazelcast.client.proxy.ClientLockProxy
- 
Deprecated. 
- getKey() - Method in class com.hazelcast.cluster.client.MemberAttributeChange
-  
- getKey() - Method in class com.hazelcast.cluster.impl.ClusterStateTransactionLogRecord
-  
- getKey() - Method in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
-  
- getKey() - Method in class com.hazelcast.collection.impl.txnqueue.QueueTransactionLogRecord
-  
- getKey() - Method in class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-  
- getKey() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-  
- getKey() - Method in class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-  
- getKey() - Method in class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-  
- getKey() - Method in class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-  
- getKey() - Method in class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-  
- getKey() - Method in class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-  
- getKey() - Method in class com.hazelcast.concurrent.lock.client.AwaitRequest
-  
- getKey() - Method in class com.hazelcast.concurrent.lock.client.BeforeAwaitRequest
-  
- getKey() - Method in class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-  
- getKey() - Method in class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-  
- getKey() - Method in class com.hazelcast.concurrent.lock.client.SignalRequest
-  
- getKey() - Method in class com.hazelcast.concurrent.lock.ConditionKey
-  
- getKey() - Method in class com.hazelcast.concurrent.lock.LockProxy
- 
Deprecated. 
- getKey() - Method in interface com.hazelcast.concurrent.lock.LockResource
-  
- getKey() - Method in class com.hazelcast.concurrent.lock.operations.BaseLockOperation
-  
- getKey() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-  
- getKey() - Method in class com.hazelcast.core.EntryEvent
- 
Returns the key of the entry event. 
- getKey() - Method in interface com.hazelcast.core.EntryView
- 
Returns the key of the entry. 
- getKey() - Method in interface com.hazelcast.core.ILock
- 
- getKey() - Method in class com.hazelcast.core.MemberAttributeEvent
- 
Returns the key for this MemberAttributeEvent. 
- getKey() - Method in class com.hazelcast.core.PartitionAwareKey
- 
Gets the key (not the partitionKey). 
- getKey() - Method in class com.hazelcast.hibernate.local.Invalidation
-  
- getKey() - Method in class com.hazelcast.hibernate.local.Timestamp
-  
- getKey() - Method in class com.hazelcast.internal.ascii.memcache.DeleteCommand
-  
- getKey() - Method in class com.hazelcast.internal.ascii.memcache.GetCommand
-  
- getKey() - Method in class com.hazelcast.internal.ascii.memcache.IncrementCommand
-  
- getKey() - Method in class com.hazelcast.internal.ascii.memcache.SetCommand
-  
- getKey() - Method in class com.hazelcast.internal.ascii.memcache.TouchCommand
-  
- getKey() - Method in class com.hazelcast.map.impl.client.MapContainsKeyRequest
-  
- getKey() - Method in class com.hazelcast.map.impl.client.MapDeleteRequest
-  
- getKey() - Method in class com.hazelcast.map.impl.client.MapEvictRequest
-  
- getKey() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-  
- getKey() - Method in class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-  
- getKey() - Method in class com.hazelcast.map.impl.client.MapGetRequest
-  
- getKey() - Method in class com.hazelcast.map.impl.client.MapKeyBasedClientRequest
-  
- getKey() - Method in class com.hazelcast.map.impl.client.MapPutRequest
-  
- getKey() - Method in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-  
- getKey() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-  
- getKey() - Method in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-  
- getKey() - Method in class com.hazelcast.map.impl.DataAwareEntryEvent
-  
- getKey() - Method in class com.hazelcast.map.impl.EntryEventFilter
-  
- getKey() - Method in class com.hazelcast.map.impl.LazyMapEntry
-  
- getKey() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntry
-  
- getKey() - Method in class com.hazelcast.map.impl.nearcache.NearCacheRecord
-  
- getKey() - Method in class com.hazelcast.map.impl.nearcache.SingleNearCacheInvalidation
-  
- getKey() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-  
- getKey() - Method in class com.hazelcast.map.impl.query.QueryResultRow
-  
- getKey() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- getKey() - Method in interface com.hazelcast.map.impl.querycache.event.QueryCacheEventData
-  
- getKey() - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- getKey() - Method in interface com.hazelcast.map.impl.record.Record
-  
- getKey() - Method in class com.hazelcast.map.impl.record.RecordReplicationInfo
-  
- getKey() - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- getKey() - Method in class com.hazelcast.map.impl.tx.MapTransactionLogRecord
-  
- getKey() - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
-  
- getKey() - Method in class com.hazelcast.multimap.impl.MultiMapEventFilter
-  
- getKey() - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
-  
- getKey() - Method in class com.hazelcast.query.impl.CachedQueryEntry
-  
- getKey() - Method in class com.hazelcast.query.impl.QueryableEntry
-  
- getKey() - Method in class com.hazelcast.query.impl.QueryEntry
-  
- getKey() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-  
- getKey() - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
-  
- getKey() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- getKey() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-  
- getKey() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventProcessor
-  
- getKey() - Method in class com.hazelcast.spi.impl.eventservice.impl.LocalEventDispatcher
-  
- getKey() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-  
- getKey() - Method in interface com.hazelcast.transaction.impl.TransactionLogRecord
- 
- getKey() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.EntryIterator
-  
- getKey() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.EntryIterator
-  
- getKey() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap.SimpleEntry
-  
- getKey() - Method in interface com.hazelcast.util.executor.StripedRunnable
-  
- getKey() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
-  
- getKeyData() - Method in class com.hazelcast.concurrent.lock.LockProxy
-  
- getKeyData() - Method in class com.hazelcast.map.impl.DataAwareEntryEvent
-  
- getKeyData() - Method in class com.hazelcast.map.impl.LazyMapEntry
-  
- getKeyData() - Method in class com.hazelcast.query.impl.CachedQueryEntry
-  
- getKeyData() - Method in class com.hazelcast.query.impl.QueryableEntry
-  
- getKeyData() - Method in class com.hazelcast.query.impl.QueryEntry
-  
- getKeyInternal() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-  
- getKeyMember(Object) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-  
- getKeys() - Method in class com.hazelcast.cache.impl.CacheKeyIteratorResult
-  
- getKeys() - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-  
- getKeys() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.AbstractMapReduceTask
-  
- getKeys() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForCustomMessageTask
-  
- getKeys() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForListMessageTask
-  
- getKeys() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMapMessageTask
-  
- getKeys() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMultiMapMessageTask
-  
- getKeys() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForSetMessageTask
-  
- getKeys(BatchNearCacheInvalidation) - Static method in class com.hazelcast.map.impl.nearcache.BatchInvalidator
-  
- getKeys() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeys
-  
- getKeySet() - Method in class com.hazelcast.map.impl.MapKeySet
-  
- getKeysExcludingSource(BatchNearCacheInvalidation, String) - Static method in class com.hazelcast.map.impl.nearcache.BatchInvalidator
-  
- getKeysFromIamRole() - Method in class com.hazelcast.jclouds.IAMRoleCredentialSupplierBuilder
-  
- getKeysFromRecords(Collection<Record>) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- getKeyStorageMemoryCost(K) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- getKeyStorageMemoryCost(K) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.NearCacheDataRecordStore
-  
- getKeyStorageMemoryCost(K) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.NearCacheObjectRecordStore
-  
- getKeyType() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
-  
- getKeyType() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Gets the key type for this  ICache. 
- getKeyValueSource() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.AbstractMapReduceTask
-  
- getKeyValueSource() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForCustomMessageTask
-  
- getKeyValueSource() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForListMessageTask
-  
- getKeyValueSource() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMapMessageTask
-  
- getKeyValueSource() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMultiMapMessageTask
-  
- getKeyValueSource() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForSetMessageTask
-  
- getKeyValueSource() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-  
- getLanguageName() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
-  
- getLanguageVersion() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
-  
- getLastAccessedTime() - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- getLastAccessTime() - Method in interface com.hazelcast.cache.CacheEntryView
- 
Gets the last access time in milliseconds of the cache entry. 
- getLastAccessTime() - Method in interface com.hazelcast.cache.CacheStatistics
- 
Gets the last access time to cache. 
- getLastAccessTime() - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- getLastAccessTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- getLastAccessTime() - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
-  
- getLastAccessTime() - Method in class com.hazelcast.cache.impl.merge.entry.LazyCacheEntryView
-  
- getLastAccessTime() - Method in interface com.hazelcast.core.EntryView
- 
Returns the last access time for the entry. 
- getLastAccessTime() - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- getLastAccessTime() - Method in interface com.hazelcast.map.impl.record.Record
-  
- getLastAccessTime() - Method in class com.hazelcast.map.impl.record.RecordInfo
-  
- getLastAccessTime() - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- getLastAccessTime() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-  
- getLastAccessTime() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getLastAccessTime() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getLastAccessTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
- 
Gets the last access time to cache. 
- getLastAccessTime() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns the last access (read) time of the locally owned entries. 
- getLastAccessTime() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-  
- getLastAccessTime() - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
-  
- getLastAccessTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- getLastAccessTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-  
- getLastCallId() - Method in class com.hazelcast.spi.impl.operationservice.impl.CallIdSequence.CallIdSequenceWithBackpressure
-  
- getLastCallId() - Method in class com.hazelcast.spi.impl.operationservice.impl.CallIdSequence.CallIdSequenceWithoutBackpressure
-  
- getLastCallId() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
-  
- getLastCleanupTime() - Method in class com.hazelcast.map.impl.PartitionContainer
-  
- getLastCleanupTimeCopy() - Method in class com.hazelcast.map.impl.PartitionContainer
-  
- getLastReadTimeMillis() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingSocketReader
-  
- getLastReadTimeMillis() - Method in interface com.hazelcast.nio.tcp.SocketReader
- 
- getLastReadTimeMillis() - Method in class com.hazelcast.nio.tcp.spinning.SpinningSocketReader
-  
- getLastStoredTime() - Method in interface com.hazelcast.core.EntryView
- 
Returns the last time the value was flushed to mapstore. 
- getLastStoredTime() - Method in class com.hazelcast.map.impl.record.EmptyRecordStatistics
-  
- getLastStoredTime() - Method in interface com.hazelcast.map.impl.record.RecordStatistics
-  
- getLastStoredTime() - Method in class com.hazelcast.map.impl.record.RecordStatisticsImpl
-  
- getLastStoredTime() - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- getLastStoredTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- getLastUpdateTime() - Method in interface com.hazelcast.cache.CacheStatistics
- 
Gets the last update time to cache. 
- getLastUpdateTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- getLastUpdateTime() - Method in interface com.hazelcast.core.EntryView
- 
Returns the last time the value was updated. 
- getLastUpdateTime() - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- getLastUpdateTime() - Method in interface com.hazelcast.map.impl.record.Record
-  
- getLastUpdateTime() - Method in class com.hazelcast.map.impl.record.RecordInfo
-  
- getLastUpdateTime() - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- getLastUpdateTime() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-  
- getLastUpdateTime() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getLastUpdateTime() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getLastUpdateTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
- 
Gets the last update time to cache. 
- getLastUpdateTime() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns the last update time of the locally owned entries. 
- getLastUpdateTime() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-  
- getLastUpdateTime() - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
-  
- getLastUpdateTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- getLastWriteTimeMillis() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingSocketWriter
-  
- getLastWriteTimeMillis() - Method in interface com.hazelcast.nio.tcp.SocketWriter
- 
- getLastWriteTimeMillis() - Method in class com.hazelcast.nio.tcp.spinning.SpinningSocketWriter
-  
- getLevel() - Method in interface com.hazelcast.logging.ILogger
- 
Gets the logging Level. 
- getLicenseKey() - Method in class com.hazelcast.client.config.ClientConfig
-  
- getLicenseKey() - Method in class com.hazelcast.config.Config
-  
- getLifecycleService() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getLifecycleService() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getLifecycleService() - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the lifecycle service for this instance. 
- getLifecycleService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getLifecycleService() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getLifecycleService() - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getLifeStartTime(Record) - Static method in class com.hazelcast.map.impl.ExpirationTimeSetter
- 
Returns last-update-time of an entry if it was updated before, otherwise it returns creation-time of the entry. 
- getLineSeperator() - Static method in class com.hazelcast.util.StringUtil
- 
Returns system property "line.seperator" 
- getLingerSeconds() - Method in class com.hazelcast.client.config.SocketOptions
- 
Gets SO_LINGER with the specified linger time in seconds 
- getList() - Method in class com.hazelcast.client.console.ClientConsoleApp
-  
- getList(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getList(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getList(String) - Method in class com.hazelcast.client.proxy.txn.TransactionContextProxy
-  
- getList(String) - Method in class com.hazelcast.client.proxy.txn.xa.XATransactionContextProxy
-  
- getList(String) - Method in class com.hazelcast.client.txn.proxy.xa.XATransactionContextProxy
-  
- getList(String) - Method in class com.hazelcast.client.txn.TransactionContextProxy
-  
- getList() - Method in class com.hazelcast.console.ConsoleApp
-  
- getList(String) - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the distributed list instance with the specified name. 
- getList(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getList(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getList(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getList(String) - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
-  
- getList(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
- 
Returns the transactional list instance with the specified name. 
- getListConfig(String) - Method in class com.hazelcast.config.Config
-  
- getListConfigs() - Method in class com.hazelcast.config.Config
-  
- getListener() - Method in class com.hazelcast.cache.impl.CacheEventListenerAdaptor
-  
- getListener() - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
-  
- getListener() - Method in interface com.hazelcast.spi.ListenerWrapperEventFilter
- 
Gets the wrapped listener. 
- getListenerAdapters() - Method in class com.hazelcast.map.impl.InternalMapListenerAdapter
-  
- getListenerConfigs() - Method in class com.hazelcast.client.config.ClientConfig
- 
- getListenerConfigs() - Method in class com.hazelcast.config.Config
-  
- getListenerConfigs() - Method in class com.hazelcast.config.QuorumConfig
-  
- getListenerConfigs() - Method in class com.hazelcast.config.ReplicatedMapConfig
-  
- getListenerService() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getListenerService() - Method in class com.hazelcast.client.spi.ClientContext
-  
- getListName() - Method in class com.hazelcast.mapreduce.impl.ListKeyValueSource
-  
- getListOfEntries(Map<String, String>) - Method in class com.hazelcast.aws.security.EC2RequestSigner
-  
- getLoadBalancer() - Method in class com.hazelcast.client.config.ClientConfig
- 
Gets LoadBalancer 
- getLoadBalancer() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getLocalAddress() - Method in class com.hazelcast.cluster.impl.BindMessage
-  
- getLocalAddress() - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-  
- getLocalAvgAge() - Method in class com.hazelcast.jmx.QueueMBean
-  
- getLocalBackupCount() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalBackupCount() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalBackupEntryCount() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalBackupEntryCount() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalBackupEntryMemoryCost() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalBackupEntryMemoryCost() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalBackupItemCount() - Method in class com.hazelcast.jmx.QueueMBean
-  
- getLocalCacheStatistics() - Method in interface com.hazelcast.cache.ICache
- 
Directly access local Cache Statistics. 
- getLocalCacheStats(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- getLocalCacheStats(String) - Method in interface com.hazelcast.monitor.MemberState
-  
- getLocalCancelledTaskCount() - Method in class com.hazelcast.jmx.ExecutorServiceMBean
-  
- getLocalClient() - Method in interface com.hazelcast.client.spi.ClientClusterService
-  
- getLocalClient() - Method in class com.hazelcast.client.spi.impl.ClientClusterServiceImpl
-  
- getLocalCompletedTaskCount() - Method in class com.hazelcast.jmx.ExecutorServiceMBean
-  
- getLocalCreationTime() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalCreationTime() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalCreationTime() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- getLocalCreationTime() - Method in class com.hazelcast.jmx.TopicMBean
-  
- getLocalDirtyEntryCount() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalDirtyEntryCount() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalEmptyPollOperationCount() - Method in class com.hazelcast.jmx.QueueMBean
-  
- getLocalEndpoint() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getLocalEndpoint() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getLocalEndpoint() - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the local Endpoint which this HazelcastInstance belongs to. 
- getLocalEndpoint() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getLocalEndpoint() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getLocalEndpoint() - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getLocalEventOperationCount() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalEventOperationCount() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalEventOperationCount() - Method in class com.hazelcast.jmx.QueueMBean
-  
- getLocalEventOperationCount() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- getLocalExecutorStats() - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- getLocalExecutorStats() - Method in interface com.hazelcast.core.IExecutorService
- 
Returns local statistics related to this executor service. 
- getLocalExecutorStats() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- getLocalExecutorStats(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- getLocalExecutorStats(String) - Method in interface com.hazelcast.monitor.MemberState
-  
- getLocalGetOperationCount() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalGetOperationCount() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalGetOperationCount() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- getLocalHits() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalHits() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalHits() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- getLocalLastAccessTime() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalLastAccessTime() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalLastAccessTime() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- getLocalLastUpdateTime() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalLastUpdateTime() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalLastUpdateTime() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- getLocalLockedEntryCount() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalLockedEntryCount() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalMapStats() - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- getLocalMapStats() - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- getLocalMapStats() - Method in interface com.hazelcast.core.IMap
- 
Returns LocalMapStats for this map. 
- getLocalMapStats(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- getLocalMapStats(String) - Method in interface com.hazelcast.monitor.MemberState
-  
- getLocalMapStatsImpl(String) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
-  
- getLocalMapStatsImpl(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- getLocalMapStatsProvider() - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- getLocalMaxAge() - Method in class com.hazelcast.jmx.QueueMBean
-  
- getLocalMaxGetLatency() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalMaxGetLatency() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalMaxGetLatency() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- getLocalMaxPutLatency() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalMaxPutLatency() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalMaxPutLatency() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- getLocalMember() - Method in interface com.hazelcast.client.ClientEngine
-  
- getLocalMember() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- getLocalMember() - Method in class com.hazelcast.client.proxy.ClientClusterProxy
-  
- getLocalMember() - Method in interface com.hazelcast.cluster.ClusterService
- 
Gets the local member instance. 
- getLocalMember() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- getLocalMember() - Method in interface com.hazelcast.core.Cluster
- 
Returns this Hazelcast instance member. 
- getLocalMember() - Method in class com.hazelcast.instance.Node
-  
- getLocalMember() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getLocalMember() - Method in interface com.hazelcast.spi.NodeEngine
- 
Returns the local member. 
- getLocalMemoryStats() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- getLocalMemoryStats() - Method in interface com.hazelcast.monitor.MemberState
-  
- getLocalMinAge() - Method in class com.hazelcast.jmx.QueueMBean
-  
- getLocalMultiMapStats() - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-  
- getLocalMultiMapStats() - Method in interface com.hazelcast.core.MultiMap
- 
Returns LocalMultiMapStats for this map. 
- getLocalMultiMapStats(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- getLocalMultiMapStats(String) - Method in interface com.hazelcast.monitor.MemberState
-  
- getLocalMultiMapStats() - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-  
- getLocalMultiMapStatsImpl(String) - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- getLocalOfferOperationCount() - Method in class com.hazelcast.jmx.QueueMBean
-  
- getLocalOtherOperationCount() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalOtherOperationCount() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalOtherOperationCount() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- getLocalOtherOperationsCount() - Method in class com.hazelcast.jmx.QueueMBean
-  
- getLocalOwnedEntryCount() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalOwnedEntryCount() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalOwnedEntryCount() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- getLocalOwnedEntryMemoryCost() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalOwnedEntryMemoryCost() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalOwnedItemCount() - Method in class com.hazelcast.jmx.QueueMBean
-  
- getLocalPartitionIds() - Method in class com.hazelcast.map.impl.query.MapQueryEngineImpl
-  
- getLocalPendingTaskCount() - Method in class com.hazelcast.jmx.ExecutorServiceMBean
-  
- getLocalPollOperationCount() - Method in class com.hazelcast.jmx.QueueMBean
-  
- getLocalPublishOperationCount() - Method in class com.hazelcast.jmx.TopicMBean
-  
- getLocalPutOperationCount() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalPutOperationCount() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalPutOperationCount() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- getLocalQueueStats() - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-  
- getLocalQueueStats() - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
-  
- getLocalQueueStats() - Method in interface com.hazelcast.core.IQueue
- 
Returns LocalQueueStats for this queue. 
- getLocalQueueStats(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- getLocalQueueStats(String) - Method in interface com.hazelcast.monitor.MemberState
-  
- getLocalQueueStatsImpl(String) - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- getLocalReceiveOperationCount() - Method in class com.hazelcast.jmx.TopicMBean
-  
- getLocalRejectedOfferOperationCount() - Method in class com.hazelcast.jmx.QueueMBean
-  
- getLocalRemoveOperationCount() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalRemoveOperationCount() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalRemoveOperationCount() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- getLocalReplicatedMapStats(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- getLocalReplicatedMapStats(String) - Method in interface com.hazelcast.monitor.MemberState
-  
- getLocalSocketAddress() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- getLocalStartedTaskCount() - Method in class com.hazelcast.jmx.ExecutorServiceMBean
-  
- getLocalStats() - Method in class com.hazelcast.jmx.LocalStatsDelegate
-  
- getLocalTopicStats() - Method in class com.hazelcast.client.proxy.ClientReliableTopicProxy
-  
- getLocalTopicStats() - Method in class com.hazelcast.client.proxy.ClientTopicProxy
-  
- getLocalTopicStats() - Method in interface com.hazelcast.core.ITopic
- 
Returns statistics about this topic, like total number of publishes/receives 
- getLocalTopicStats(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- getLocalTopicStats(String) - Method in interface com.hazelcast.monitor.MemberState
-  
- getLocalTopicStats() - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicProxy
-  
- getLocalTopicStats() - Method in class com.hazelcast.topic.impl.TopicProxy
-  
- getLocalTopicStats(String) - Method in class com.hazelcast.topic.impl.TopicService
-  
- getLocalTopicStatsInternal() - Method in class com.hazelcast.topic.impl.TopicProxySupport
-  
- getLocalTotalExecutionLatency() - Method in class com.hazelcast.jmx.ExecutorServiceMBean
-  
- getLocalTotalGetLatency() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalTotalGetLatency() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalTotalGetLatency() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- getLocalTotalPutLatency() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalTotalPutLatency() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalTotalPutLatency() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- getLocalTotalRemoveLatency() - Method in class com.hazelcast.jmx.MapMBean
-  
- getLocalTotalRemoveLatency() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getLocalTotalRemoveLatency() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- getLocalTotalStartLatency() - Method in class com.hazelcast.jmx.ExecutorServiceMBean
-  
- getLocalTransaction() - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getLocalTransaction() - Method in class com.hazelcast.jca.ManagedConnectionImpl
-  
- getLocalUpdatePolicy() - Method in class com.hazelcast.config.NearCacheConfig
-  
- getLocalWanPublisherStats() - Method in class com.hazelcast.monitor.impl.LocalWanStatsImpl
-  
- getLocalWanPublisherStats() - Method in interface com.hazelcast.monitor.LocalWanStats
- 
Returns the statistics of different publisher clusters belongs the scheme on this member 
- getLocalWanStats(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- getLocalWanStats(String) - Method in interface com.hazelcast.monitor.MemberState
-  
- getLock(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getLock(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getLock(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- getLock(String) - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the distributed lock instance for the specified key object. 
- getLock(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getLock(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getLock(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getLockContainer(int) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-  
- getLockCount() - Method in class com.hazelcast.client.proxy.ClientLockProxy
-  
- getLockCount() - Method in class com.hazelcast.concurrent.lock.LockProxy
-  
- getLockCount(NodeEngine, Data) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
-  
- getLockCount() - Method in interface com.hazelcast.concurrent.lock.LockResource
-  
- getLockCount(Data) - Method in interface com.hazelcast.concurrent.lock.LockStore
-  
- getLockCount(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- getLockCount(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
-  
- getLockCount() - Method in interface com.hazelcast.core.ILock
- 
Returns re-entrant lock hold count, regardless of lock ownership. 
- getLockCount() - Method in class com.hazelcast.jmx.LockMBean
-  
- GetLockCountOperation - Class in com.hazelcast.concurrent.lock.operations
-  
- GetLockCountOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.GetLockCountOperation
-  
- GetLockCountOperation(ObjectNamespace, Data) - Constructor for class com.hazelcast.concurrent.lock.operations.GetLockCountOperation
-  
- GetLockCountRequest - Class in com.hazelcast.concurrent.lock.client
-  
- GetLockCountRequest() - Constructor for class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-  
- GetLockCountRequest(Data) - Constructor for class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-  
- getLockedCount() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-  
- getLockedEntryCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getLockedEntryCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getLockedEntryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns the number of currently locked locally owned keys. 
- getLockedKeys() - Method in interface com.hazelcast.concurrent.lock.LockStore
-  
- getLockedKeys() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- getLockedKeys() - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
-  
- getLockObject() - Method in class com.hazelcast.jmx.LockMBean
-  
- getLockOwnerInfo(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- getLockOwnerInfo(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- getLockOwnerInfo(Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-  
- getLocks() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- getLockStore(int, ObjectNamespace) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-  
- getLockStore() - Method in class com.hazelcast.concurrent.lock.operations.BaseLockOperation
-  
- getLockStores() - Method in class com.hazelcast.concurrent.lock.LockStoreContainer
-  
- getLockTimeoutInMillis(Properties) - Static method in class com.hazelcast.hibernate.CacheEnvironment
-  
- getLogger(Class) - Method in interface com.hazelcast.client.ClientEngine
-  
- getLogger(Class) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- getLogger() - Method in class com.hazelcast.client.impl.MemberImpl
-  
- getLogger() - Method in interface com.hazelcast.hibernate.region.HazelcastRegion
-  
- getLogger() - Method in class com.hazelcast.instance.AbstractMember
-  
- getLogger() - Method in class com.hazelcast.instance.MemberImpl
-  
- getLogger(String) - Method in class com.hazelcast.instance.Node
-  
- getLogger(Class) - Method in class com.hazelcast.instance.Node
-  
- getLogger(Class) - Static method in class com.hazelcast.logging.Logger
-  
- getLogger(String) - Static method in class com.hazelcast.logging.Logger
-  
- getLogger(String) - Method in interface com.hazelcast.logging.LoggerFactory
-  
- getLogger(String) - Method in class com.hazelcast.logging.LoggerFactorySupport
-  
- getLogger(String) - Method in interface com.hazelcast.logging.LoggingService
-  
- getLogger(Class) - Method in interface com.hazelcast.logging.LoggingService
-  
- getLogger(String) - Method in class com.hazelcast.logging.LoggingServiceImpl
-  
- getLogger(Class) - Method in class com.hazelcast.logging.LoggingServiceImpl
-  
- getLogger(String) - Method in class com.hazelcast.logging.NoLogFactory
-  
- getLogger(Class) - Method in interface com.hazelcast.map.impl.mapstore.MapStoreContext
-  
- getLogger(String) - Method in interface com.hazelcast.nio.IOService
-  
- getLogger(String) - Method in class com.hazelcast.nio.NodeIOService
-  
- getLogger() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
- 
Returns a  ILogger instance bound to the current class. 
- getLogger() - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-  
- getLogger(String) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getLogger(Class) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getLogger(String) - Method in interface com.hazelcast.spi.NodeEngine
- 
Gets the logger for a given name. 
- getLogger(Class) - Method in interface com.hazelcast.spi.NodeEngine
- 
Gets the logger for a given class. 
- getLogger() - Method in class com.hazelcast.spi.Operation
-  
- getLoggingService() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getLoggingService() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getLoggingService() - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the logging service of this Hazelcast instance. 
- getLoggingService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getLoggingService() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getLoggingService() - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getLogRecord() - Method in class com.hazelcast.logging.LogEvent
-  
- GetLogsRequest - Class in com.hazelcast.internal.management.request
- 
Deprecated. 
- GetLogsRequest() - Constructor for class com.hazelcast.internal.management.request.GetLogsRequest
- 
Deprecated. 
- getLogWriter() - Method in class com.hazelcast.jca.JcaBase
-  
- getLong(int) - Method in interface com.hazelcast.client.impl.protocol.util.ClientProtocolBuffer
- 
Get the value at a given index. 
- getLong() - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- getLong(int) - Method in class com.hazelcast.client.impl.protocol.util.SafeBuffer
-  
- getLong(int) - Method in class com.hazelcast.client.impl.protocol.util.UnsafeBuffer
-  
- getLong(HazelcastProperty) - Method in class com.hazelcast.instance.HazelcastProperties
- 
- getLong(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
- 
Returns a field in a Json object as a long. 
- getLong(JsonObject, String, long) - Static method in class com.hazelcast.util.JsonUtil
- 
Returns a field in a Json object as a long. 
- getLongAttribute(String) - Method in class com.hazelcast.client.impl.MemberImpl
-  
- getLongAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-  
- getLongAttribute(String) - Method in interface com.hazelcast.core.Member
- 
Returns the value of the specified key for this member or
 null if value is undefined. 
- getLongAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-  
- getLongContainer(String) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-  
- getLongContainer() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
-  
- getLongValue(String, String) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
-  
- getLostBackupCount() - Method in class com.hazelcast.partition.PartitionLostEvent
- 
Returns the number of lost backups for the partition. 
- getLostBackupCount() - Method in class com.hazelcast.spi.impl.PortablePartitionLostEvent
-  
- getLostReplicaIndex() - Method in class com.hazelcast.partition.InternalPartitionLostEvent
- 
0-based replica index that is lost for the partition
 For instance, 0 means only the owner of the partition is lost, 1 means both the owner and first backup are lost 
- getMajorCollectionCount() - Method in class com.hazelcast.memory.DefaultGarbageCollectorStats
-  
- getMajorCollectionCount() - Method in interface com.hazelcast.memory.GarbageCollectorStats
- 
Returns major collection count. 
- getMajorCollectionCount() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-  
- getMajorCollectionTime() - Method in class com.hazelcast.memory.DefaultGarbageCollectorStats
-  
- getMajorCollectionTime() - Method in interface com.hazelcast.memory.GarbageCollectorStats
- 
Returns total major collection time in ms. 
- getMajorCollectionTime() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-  
- getManagedContext() - Method in class com.hazelcast.client.config.ClientConfig
- 
- getManagedContext() - Method in class com.hazelcast.config.Config
-  
- getManagedContext() - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- getManagedContext() - Method in interface com.hazelcast.internal.serialization.PortableContext
-  
- getManagedContext() - Method in interface com.hazelcast.internal.serialization.SerializationService
-  
- getManagedExecutorBean(String) - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
-  
- getManagementCenterConfig() - Method in class com.hazelcast.config.Config
-  
- getManagementCenterService() - Method in class com.hazelcast.instance.Node
-  
- getManagementCenterService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getManagementService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getManagerClassLoader(ClassLoader) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-  
- getManagerPrefix() - Method in class com.hazelcast.config.CacheConfig
- 
Gets the manager prefix of the  ICache, such as "hz://". 
- getManagerUri(URI) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-  
- getMap() - Method in class com.hazelcast.client.console.ClientConsoleApp
-  
- getMap(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getMap(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getMap(String) - Method in class com.hazelcast.client.proxy.txn.TransactionContextProxy
-  
- getMap(String) - Method in class com.hazelcast.client.proxy.txn.xa.XATransactionContextProxy
-  
- getMap(String) - Method in class com.hazelcast.client.txn.proxy.xa.XATransactionContextProxy
-  
- getMap(String) - Method in class com.hazelcast.client.txn.TransactionContextProxy
-  
- getMap() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- getMap() - Method in class com.hazelcast.collection.impl.list.ListContainer
-  
- getMap() - Method in class com.hazelcast.collection.impl.set.SetContainer
-  
- getMap() - Method in class com.hazelcast.console.ConsoleApp
-  
- getMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the distributed map instance with the specified name. 
- getMap(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getMap(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getMap(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getMap(String) - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
-  
- getMap(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
- 
Returns the transactional distributed map instance with the specified name. 
- getMapAttributeConfigs() - Method in class com.hazelcast.config.MapConfig
-  
- getMapCombineTask(String) - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-  
- getMapConfig(String) - Method in class com.hazelcast.config.Config
-  
- getMapConfig() - Method in class com.hazelcast.internal.management.dto.MapConfigDTO
-  
- getMapConfig() - Method in class com.hazelcast.map.impl.MapContainer
-  
- GetMapConfigOperation - Class in com.hazelcast.internal.management.operation
- 
Operation to fetch Map configuration. 
- GetMapConfigOperation() - Constructor for class com.hazelcast.internal.management.operation.GetMapConfigOperation
-  
- GetMapConfigOperation(String) - Constructor for class com.hazelcast.internal.management.operation.GetMapConfigOperation
-  
- getMapConfigs() - Method in class com.hazelcast.config.Config
-  
- getMapContainer(String) - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- getMapContainer() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- getMapContainers() - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- getMapDataStore(int) - Method in interface com.hazelcast.map.impl.mapstore.MapStoreManager
-  
- getMapDataStore(int) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindManager
-  
- getMapDataStore(int) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughManager
-  
- getMapDataStore() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- getMapDataStore() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- GetMapEntryRequest - Class in com.hazelcast.internal.management.request
- 
Request for fetching map entries. 
- GetMapEntryRequest() - Constructor for class com.hazelcast.internal.management.request.GetMapEntryRequest
-  
- GetMapEntryRequest(String, String, String) - Constructor for class com.hazelcast.internal.management.request.GetMapEntryRequest
-  
- getMapEventPublisher() - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- getMapIndexConfigs() - Method in class com.hazelcast.config.MapConfig
-  
- getMapIndexConfigs() - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- getMapListener() - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
-  
- getMapName() - Method in interface com.hazelcast.map.impl.event.EventData
-  
- getMapName() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreContext
-  
- getMapName() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- getMapName() - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
-  
- getMapName() - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
-  
- getMapName() - Method in class com.hazelcast.mapreduce.impl.MapKeyValueSource
-  
- getMapName() - Method in class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-  
- getMapOperationProvider(String) - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- getMapOperationProvider(MapConfig) - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- getMapper() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.AbstractMapReduceTask
-  
- getMapper() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForCustomMessageTask
-  
- getMapper() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForListMessageTask
-  
- getMapper() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMapMessageTask
-  
- getMapper() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMultiMapMessageTask
-  
- getMapper() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForSetMessageTask
-  
- getMapper(Supplier<Key, ?, Supplied>) - Method in interface com.hazelcast.mapreduce.aggregation.Aggregation
- 
Returns the Mapper for this aggregation. 
- getMapper(Supplier<KeyIn, ValueIn, SuppliedValue>) - Method in interface com.hazelcast.mapreduce.aggregation.impl.AggType
-  
- getMapper(Supplier<Key, Value, BigDecimal>) - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalAvgAggregation
-  
- getMapper(Supplier<Key, Value, BigDecimal>) - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMaxAggregation
-  
- getMapper(Supplier<Key, Value, BigDecimal>) - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMinAggregation
-  
- getMapper(Supplier<Key, Value, BigDecimal>) - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalSumAggregation
-  
- getMapper(Supplier<Key, Value, BigInteger>) - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerAvgAggregation
-  
- getMapper(Supplier<Key, Value, BigInteger>) - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMaxAggregation
-  
- getMapper(Supplier<Key, Value, BigInteger>) - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMinAggregation
-  
- getMapper(Supplier<Key, Value, BigInteger>) - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerSumAggregation
-  
- getMapper(Supplier<Key, Value, Comparable>) - Method in class com.hazelcast.mapreduce.aggregation.impl.ComparableMaxAggregation
-  
- getMapper(Supplier<Key, Value, Comparable>) - Method in class com.hazelcast.mapreduce.aggregation.impl.ComparableMinAggregation
-  
- getMapper(Supplier<Key, Value, Object>) - Method in class com.hazelcast.mapreduce.aggregation.impl.CountAggregation
-  
- getMapper(Supplier<Key, Value, DistinctType>) - Method in class com.hazelcast.mapreduce.aggregation.impl.DistinctValuesAggregation
-  
- getMapper(Supplier<Key, Value, Double>) - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleAvgAggregation
-  
- getMapper(Supplier<Key, Value, Double>) - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleMaxAggregation
-  
- getMapper(Supplier<Key, Value, Double>) - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleMinAggregation
-  
- getMapper(Supplier<Key, Value, Double>) - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleSumAggregation
-  
- getMapper(Supplier<Key, Value, Integer>) - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerAvgAggregation
-  
- getMapper(Supplier<Key, Value, Integer>) - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerMaxAggregation
-  
- getMapper(Supplier<Key, Value, Integer>) - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerMinAggregation
-  
- getMapper(Supplier<Key, Value, Integer>) - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerSumAggregation
-  
- getMapper(Supplier<Key, Value, Long>) - Method in class com.hazelcast.mapreduce.aggregation.impl.LongAvgAggregation
-  
- getMapper(Supplier<Key, Value, Long>) - Method in class com.hazelcast.mapreduce.aggregation.impl.LongMaxAggregation
-  
- getMapper(Supplier<Key, Value, Long>) - Method in class com.hazelcast.mapreduce.aggregation.impl.LongMinAggregation
-  
- getMapper(Supplier<Key, Value, Long>) - Method in class com.hazelcast.mapreduce.aggregation.impl.LongSumAggregation
-  
- getMapper() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-  
- getMapQueryEngine(String) - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- getMapReduceService() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-  
- getMaps() - Method in class com.hazelcast.map.impl.PartitionContainer
-  
- getMapService() - Method in class com.hazelcast.map.impl.PartitionContainer
-  
- getMapServiceContext() - Method in class com.hazelcast.map.impl.MapContainer
-  
- getMapServiceContext() - Method in class com.hazelcast.map.impl.MapService
-  
- getMapServiceContext() - Method in interface com.hazelcast.map.impl.MapServiceFactory
- 
- getMapServiceContext() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreContext
-  
- getMapStore() - Method in class com.hazelcast.map.impl.MapStoreWrapper
-  
- getMapStoreConfig() - Method in class com.hazelcast.config.MapConfig
- 
Returns the map store configuration 
- getMapStoreConfig() - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- getMapStoreConfig() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreContext
-  
- getMapStoreContext() - Method in class com.hazelcast.map.impl.MapContainer
-  
- getMapStoreManager() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreContext
-  
- getMapStoreWrapper() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreContext
-  
- getMarker() - Method in class com.hazelcast.hibernate.serialization.MarkerWrapper
-  
- getMaster() - Method in class com.hazelcast.monitor.TimedMemberState
-  
- getMaster() - Method in class com.hazelcast.partition.MigrationInfo
-  
- getMasterAddress() - Method in interface com.hazelcast.client.ClientEngine
-  
- getMasterAddress() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- getMasterAddress() - Method in interface com.hazelcast.client.spi.ClientClusterService
- 
Returns the address of the master member. 
- getMasterAddress() - Method in class com.hazelcast.client.spi.impl.ClientClusterServiceImpl
-  
- getMasterAddress() - Method in interface com.hazelcast.cluster.ClusterService
- 
Returns the address of the master member. 
- getMasterAddress() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- getMasterAddress() - Method in class com.hazelcast.cluster.impl.operations.SetMasterOperation
-  
- getMasterAddress() - Method in class com.hazelcast.instance.Node
-  
- getMasterAddress() - Method in class com.hazelcast.jmx.NodeMBean
-  
- getMasterAddress() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getMasterAddress() - Method in interface com.hazelcast.spi.NodeEngine
- 
Gets the address of the master member. 
- getMasterUuid() - Method in class com.hazelcast.partition.MigrationInfo
-  
- getMatchingIpv4Addresses(AddressUtil.AddressMatcher) - Static method in class com.hazelcast.util.AddressUtil
-  
- getMaxAge() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- getMaxAge() - Method in interface com.hazelcast.monitor.LocalQueueStats
- 
Returns the maximum age of the items in this member. 
- getMaxBackupCount() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getMaxBackupCount() - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- getMaxConcurrentInvocations() - Method in class com.hazelcast.spi.impl.operationservice.impl.CallIdSequence.CallIdSequenceWithBackpressure
-  
- getMaxConcurrentInvocations() - Method in class com.hazelcast.spi.impl.operationservice.impl.CallIdSequence.CallIdSequenceWithoutBackpressure
-  
- getMaxConcurrentInvocations() - Method in class com.hazelcast.spi.impl.operationservice.impl.CallIdSequence
- 
Returns the maximum concurrent invocations supported. 
- getMaxGetLatency() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getMaxGetLatency() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getMaxGetLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns the maximum latency of get operations. 
- getMaxHeap() - Method in class com.hazelcast.memory.DefaultMemoryStats
-  
- getMaxHeap() - Method in interface com.hazelcast.memory.MemoryStats
- 
Returns the maximum amount of memory that the JVM will attempt to use in bytes. 
- getMaxHeap() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- getMaxIdleSeconds() - Method in class com.hazelcast.config.MapConfig
- 
Returns the maximum number of seconds for each entry to stay idle in the map. 
- getMaxIdleSeconds() - Method in class com.hazelcast.config.NearCacheConfig
- 
Maximum number of seconds each entry can stay in the near cache as untouched (not-read). 
- getMaximumPoolSize() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-  
- getMaximumPoolSize() - Method in interface com.hazelcast.util.executor.ManagedExecutorService
-  
- getMaximumSizePolicy() - Method in class com.hazelcast.config.EvictionConfig
-  
- getMaxInactiveInterval() - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- getMaxJoinMillis() - Method in class com.hazelcast.cluster.impl.AbstractJoiner
-  
- getMaxJoinTimeToMasterNode() - Method in class com.hazelcast.cluster.impl.AbstractJoiner
-  
- getMaxLeaseTimeInMillis() - Method in interface com.hazelcast.concurrent.lock.LockService
-  
- getMaxLeaseTimeInMillis() - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-  
- getMaxLeaseTimeInMillis(GroupProperties) - Static method in class com.hazelcast.concurrent.lock.LockServiceImpl
-  
- getMaxMemory() - Method in class com.hazelcast.map.impl.eviction.EvictionCheckerImpl
-  
- getMaxMemory() - Method in interface com.hazelcast.util.MemoryInfoAccessor
- 
Returns the maximum amount of memory that the Java virtual machine will attempt to use in bytes. 
- getMaxMemory() - Method in class com.hazelcast.util.RuntimeMemoryInfoAccessor
-  
- getMaxNativeMemory() - Method in class com.hazelcast.memory.DefaultMemoryStats
-  
- getMaxNativeMemory() - Method in interface com.hazelcast.memory.MemoryStats
- 
Returns the maximum amount of native memory that current HazelcastInstance
 will attempt to use in bytes. 
- getMaxNativeMemory() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- getMaxOperationTimeout(HazelcastInstance) - Static method in class com.hazelcast.hibernate.HazelcastTimestamper
-  
- getMaxPutLatency() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getMaxPutLatency() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getMaxPutLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns the maximum latency of put operations. 
- getMaxRemoveLatency() - Method in class com.hazelcast.jmx.MapMBean
-  
- getMaxRemoveLatency() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getMaxRemoveLatency() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- getMaxRemoveLatency() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getMaxRemoveLatency() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getMaxRemoveLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns the maximum latency of remove operations. 
- getMaxSize() - Method in class com.hazelcast.config.CollectionConfig
- 
Gets the maximum size for the Configuration. 
- getMaxSize() - Method in class com.hazelcast.config.NearCacheConfig
- 
Gets the maximum size of the near cache. 
- getMaxSize() - Method in class com.hazelcast.config.QueueConfig
- 
Returns the maximum size of the Queue. 
- getMaxSizeConfig() - Method in class com.hazelcast.config.MapConfig
-  
- getMaxSizeConfig() - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- getMaxSizePerNode(MaxSizeConfig) - Static method in class com.hazelcast.map.impl.MapKeyLoaderUtil
-  
- getMaxSizePolicy() - Method in class com.hazelcast.config.CacheEvictionConfig
- 
- getMaxSizePolicy() - Method in class com.hazelcast.config.MaxSizeConfig
- 
Returns the maximum size policy of the map. 
- getMaxThreadSize() - Method in class com.hazelcast.config.JobTrackerConfig
- 
Gets the maximum thread pool size of this  JobTracker. 
- getMaxVisibleSlowOperationCount() - Method in class com.hazelcast.monitor.impl.LocalOperationStatsImpl
-  
- getMBeanInfo() - Method in class com.hazelcast.jmx.HazelcastMBean
-  
- getMBeanServerId() - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-  
- getMember() - Method in class com.hazelcast.cache.impl.CachePartitionEventData
-  
- getMember() - Method in class com.hazelcast.cache.impl.event.AbstractICacheEvent
- 
Returns the member that fired this event. 
- getMember() - Method in interface com.hazelcast.cache.impl.event.ICacheEvent
- 
Returns the member that fired this event. 
- getMember(Address) - Method in interface com.hazelcast.client.spi.ClientClusterService
- 
Gets the member for the given address. 
- getMember(String) - Method in interface com.hazelcast.client.spi.ClientClusterService
- 
Gets the member with the given uuid. 
- getMember(Address) - Method in class com.hazelcast.client.spi.impl.ClientClusterServiceImpl
-  
- getMember(String) - Method in class com.hazelcast.client.spi.impl.ClientClusterServiceImpl
-  
- getMember() - Method in class com.hazelcast.cluster.client.ClientInitialMembershipEvent
- 
Returns the removed or added member. 
- getMember() - Method in class com.hazelcast.cluster.client.ClientMembershipEvent
- 
Returns the removed or added member. 
- getMember(Address) - Method in interface com.hazelcast.cluster.ClusterService
- 
Gets the member for the given address. 
- getMember(String) - Method in interface com.hazelcast.cluster.ClusterService
- 
Gets the member with the given uuid. 
- getMember(Address) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- getMember(String) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- getMember() - Method in class com.hazelcast.core.AbstractIMapEvent
- 
Returns the member that fired this event. 
- getMember() - Method in interface com.hazelcast.core.IMapEvent
- 
Returns the member that fired this event. 
- getMember() - Method in class com.hazelcast.core.ItemEvent
- 
Returns the member that fired this event. 
- getMember() - Method in class com.hazelcast.core.MemberAttributeEvent
-  
- getMember() - Method in exception com.hazelcast.core.MemberLeftException
- 
Returns the member that left the cluster 
- getMember() - Method in class com.hazelcast.core.MembershipEvent
- 
Returns the removed or added member. 
- getMember() - Method in class com.hazelcast.logging.LogEvent
-  
- getMember() - Method in class com.hazelcast.map.impl.nearcache.Invalidation
-  
- getMember(Address) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getMember(Address) - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- getMember() - Method in class com.hazelcast.spi.MembershipServiceEvent
- 
Returns the removed or added member. 
- getMemberAddresses() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- getMemberAddresses() - Method in class com.hazelcast.cluster.impl.JoinMessage
-  
- getMemberAddresses() - Method in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
-  
- getMemberAddresses() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperation
-  
- getMemberAttributeChange() - Method in class com.hazelcast.cluster.client.ClientInitialMembershipEvent
- 
- getMemberAttributeChange() - Method in class com.hazelcast.cluster.client.ClientMembershipEvent
- 
- getMemberAttributeConfig() - Method in class com.hazelcast.config.Config
-  
- getMemberCount() - Method in class com.hazelcast.cluster.impl.JoinMessage
-  
- getMemberCount() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getMemberCredentialsConfig() - Method in class com.hazelcast.config.SecurityConfig
-  
- getMemberGroupConfigs() - Method in class com.hazelcast.config.PartitionGroupConfig
- 
- getMemberGroupsSize() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getMemberGroupsSize() - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- getMemberImpls() - Method in interface com.hazelcast.cluster.ClusterService
- 
Gets the collection of members. 
- getMemberImpls() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- getMemberList() - Method in interface com.hazelcast.client.spi.ClientClusterService
- 
Gets the collection of members. 
- getMemberList() - Method in class com.hazelcast.client.spi.impl.ClientClusterServiceImpl
-  
- getMemberList() - Method in class com.hazelcast.monitor.TimedMemberState
-  
- GetMemberListRequest - Class in com.hazelcast.client.impl.client
- 
Returns member list to client 
- GetMemberListRequest() - Constructor for class com.hazelcast.client.impl.client.GetMemberListRequest
-  
- getMemberLoginModuleConfigs() - Method in class com.hazelcast.config.SecurityConfig
-  
- getMemberPartitions(Address) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getMemberPartitions(Address) - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- getMemberPartitionsMap() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getMemberPartitionsMap() - Method in interface com.hazelcast.partition.InternalPartitionService
- 
Gets member partition IDs. 
- getMemberPartitionState() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- getMemberPartitionState() - Method in interface com.hazelcast.monitor.MemberState
-  
- getMembers() - Method in class com.hazelcast.client.proxy.ClientClusterProxy
-  
- getMembers(MemberSelector) - Method in interface com.hazelcast.client.spi.ClientClusterService
- 
Returns a collection of the members that satisfy the given  MemberSelector. 
- getMembers(MemberSelector) - Method in class com.hazelcast.client.spi.impl.ClientClusterServiceImpl
-  
- getMembers() - Method in class com.hazelcast.client.util.AbstractLoadBalancer
-  
- getMembers() - Method in class com.hazelcast.cluster.client.ClientInitialMembershipEvent
- 
Returns member list after initial registration. 
- getMembers(MemberSelector) - Method in interface com.hazelcast.cluster.ClusterService
- 
Returns a collection of the members that satisfy the given  MemberSelector. 
- getMembers() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- getMembers(MemberSelector) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- getMembers() - Method in class com.hazelcast.cluster.impl.TcpIpJoiner
-  
- getMembers() - Method in class com.hazelcast.cluster.impl.TcpIpJoinerOverAWS
-  
- getMembers() - Method in class com.hazelcast.config.TcpIpConfig
- 
Gets a list of all the well known members. 
- getMembers() - Method in interface com.hazelcast.core.Cluster
- 
Set of the current members in the cluster. 
- getMembers() - Method in class com.hazelcast.core.InitialMembershipEvent
- 
- getMembers() - Method in class com.hazelcast.core.MembershipEvent
- 
Returns a consistent view of the the members immediately after this MembershipEvent has been processed. 
- getMembers() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getMembers() - Method in class com.hazelcast.partition.client.PartitionsResponse
-  
- getMembers() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
-  
- getMembers() - Method in class com.hazelcast.partition.PartitionRuntimeState
-  
- getMemberSocketInterceptor() - Method in class com.hazelcast.instance.DefaultNodeExtension
-  
- getMemberSocketInterceptor() - Method in interface com.hazelcast.instance.NodeExtension
- 
Returns MemberSocketInterceptor for this Node if available,
 otherwise returns null. 
- getMemberSocketInterceptor() - Method in interface com.hazelcast.nio.IOService
-  
- getMemberSocketInterceptor() - Method in class com.hazelcast.nio.NodeIOService
-  
- getMembersRemovedWhileClusterIsNotActive() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- getMemberState() - Method in class com.hazelcast.monitor.TimedMemberState
-  
- getMemberState() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- GetMemberSystemPropertiesRequest - Class in com.hazelcast.internal.management.request
- 
Request for fetching member system properties. 
- GetMemberSystemPropertiesRequest() - Constructor for class com.hazelcast.internal.management.request.GetMemberSystemPropertiesRequest
-  
- getMemoryCost() - Method in class com.hazelcast.map.impl.record.EmptyRecordStatistics
-  
- getMemoryCost() - Method in interface com.hazelcast.map.impl.record.RecordStatistics
-  
- getMemoryCost() - Method in class com.hazelcast.map.impl.record.RecordStatisticsImpl
-  
- getMemoryLimit() - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
-  
- getMemoryStats() - Method in class com.hazelcast.instance.DefaultNodeExtension
-  
- getMemoryStats() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getMemoryStats() - Method in interface com.hazelcast.instance.NodeExtension
- 
Returns MemoryStats of for the JVM and current HazelcastInstance. 
- getMemoryStats() - Method in class com.hazelcast.internal.management.TimedMemberStateFactory
-  
- getMergePolicy(String) - Method in class com.hazelcast.cache.impl.merge.policy.CacheMergePolicyProvider
-  
- getMergePolicy() - Method in class com.hazelcast.config.CacheConfig
- 
- getMergePolicy() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
- getMergePolicy() - Method in class com.hazelcast.config.MapConfig
- 
- getMergePolicy() - Method in class com.hazelcast.config.ReplicatedMapConfig
- 
- getMergePolicy() - Method in class com.hazelcast.config.WanReplicationRef
-  
- getMergePolicy() - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
-  
- getMergePolicy(String) - Method in class com.hazelcast.map.merge.MergePolicyProvider
-  
- getMergePolicy(String) - Method in class com.hazelcast.replicatedmap.merge.MergePolicyProvider
-  
- getMergePolicyProvider() - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- getMergingValue() - Method in class com.hazelcast.core.EntryEvent
- 
Returns the incoming merging value of the entry event. 
- getMergingValue() - Method in class com.hazelcast.map.impl.DataAwareEntryEvent
-  
- getMergingValue() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-  
- getMergingValueData() - Method in class com.hazelcast.map.impl.DataAwareEntryEvent
-  
- getMessage() - Method in class com.hazelcast.client.impl.client.GenericError
-  
- getMessage() - Method in class com.hazelcast.topic.impl.client.PortableMessage
-  
- getMessageData() - Method in class com.hazelcast.topic.impl.DataAwareMessage
-  
- getMessageListenerConfigs() - Method in class com.hazelcast.config.ReliableTopicConfig
- 
Gets the list of message listeners (listens for when messages are added or removed) for this reliable topic. 
- getMessageListenerConfigs() - Method in class com.hazelcast.config.TopicConfig
- 
Gets the list of message listeners (listens for when messages are added or removed) for this topic. 
- getMessageListenerConfigs() - Method in class com.hazelcast.config.TopicConfigReadOnly
-  
- getMessageObject() - Method in class com.hazelcast.core.Message
- 
Returns the published message 
- getMessageObject() - Method in class com.hazelcast.topic.impl.DataAwareMessage
-  
- getMessageType() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
- 
Returns the message type field. 
- getMetaData() - Method in class com.hazelcast.jca.ConnectionFactoryImpl
-  
- getMetaData() - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getMetaData() - Method in class com.hazelcast.jca.ManagedConnectionImpl
-  
- getMetadataSpacePercentage() - Method in class com.hazelcast.config.NativeMemoryConfig
-  
- getMethodCallSyntax(String, String, String...) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
-  
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
-  
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CacheAddPartitionLostListenerRequest
-  
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CacheClearRequest
-  
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CacheContainsKeyRequest
-  
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CacheEntryProcessorRequest
-  
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CacheGetAllRequest
-  
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CacheGetAndRemoveRequest
-  
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CacheGetRequest
-  
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CacheIterateRequest
-  
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
-  
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-  
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CachePutAllRequest
-  
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CachePutIfAbsentRequest
-  
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CachePutRequest
-  
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CacheRemoveEntryListenerRequest
-  
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CacheRemovePartitionLostListenerRequest
-  
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CacheRemoveRequest
-  
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CacheReplaceRequest
-  
- getMethodName() - Method in class com.hazelcast.client.impl.client.AddDistributedObjectListenerRequest
-  
- getMethodName() - Method in class com.hazelcast.client.impl.client.ClientRequest
-  
- getMethodName() - Method in class com.hazelcast.client.impl.client.GetDistributedObjectsRequest
-  
- getMethodName() - Method in class com.hazelcast.client.impl.client.RemoveDistributedObjectListenerRequest
-  
- getMethodName() - Method in interface com.hazelcast.client.impl.client.SecureRequest
- 
Used for  SecurityInterceptor
 Method name which called via a distributedObject
 for map.put, methodName will be 'put'
 For requests which do not produced via a distributedObject should return null, for example internal client. 
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAddAndGetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterAndGetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongApplyMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongCompareAndSetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongDecrementAndGetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAddMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAlterMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndIncrementMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndSetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongIncrementAndGetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongSetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterAndGetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceApplyMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceClearMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceCompareAndSetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceContainsMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndAlterMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndSetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceIsNullMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetAndGetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationCustomCredentialsMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.AbstractCacheMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddEntryListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddInvalidationListenerTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheContainsKeyMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheCreateConfigMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEntryProcessorMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndRemoveMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutIfAbsentMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheReplaceMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionAwaitMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionBeforeAwaitMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchAwaitMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchCountDownMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchGetCountMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchTrySetCountMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.AbstractExecutorServiceCancelMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllWithIndexMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddWithIndexMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListClearMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRemoveAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRetainAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIndexOfMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIsEmptyMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIteratorMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListLastIndexOfMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListListIteratorMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveWithIndexMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSizeMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSubMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockForceUnlockMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockGetLockCountMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockGetRemainingLeaseTimeMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockIsLockedByCurrentThreadMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockIsLockedMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockLockMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockTryLockMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockUnlockMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapAddEntryListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddIndexMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddInterceptorMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearNearCacheMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsKeyMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsValueMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapDeleteMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPagingPredicateMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPredicateMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntrySetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnAllKeysMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeyMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeysMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteWithPredicateMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetEntryViewMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPagingPredicateMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutTransientMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveEntryListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveIfSameMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveInterceptorMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemovePartitionLostListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapReplaceIfSameMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapReplaceMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSizeMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSubmitToKeyMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryLockMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryPutMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryRemoveMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapUnlockMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPagingPredicateMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPredicateMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.AbstractMapReduceTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceCancelMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceJobProcessInformationMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.AbstractMultiMapAddEntryListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapClearMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsEntryMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsKeyMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsValueMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapGetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapPutMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValueCountMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.NoSuchMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueClearMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRemoveAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRetainAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMaxSizeMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIsEmptyMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIteratorMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueOfferMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePeekMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePollMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePutMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemainingCapacityMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueSizeMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueTakeMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsKeyMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsValueMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapEntrySetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapIsEmptyMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapKeySetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapSizeMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapValuesMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferCapacityMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferHeadSequenceMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadManyMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadOneMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferRemainingCapacityMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferSizeMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferTailSequenceMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreAcquireMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreAvailablePermitsMessageTasks
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreDrainPermitsMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreInitMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreReducePermitsMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreReleaseMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreTryAcquireMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetClearMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRemoveAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRetainAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetGetAllMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetIsEmptyMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetSizeMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicAddMessageListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicPublishMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicRemoveMessageListenerMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCommitMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCreateMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionRollbackMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAClearRemoteTransactionMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XACollectTransactionsMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAFinalizeTransactionMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCommitMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCreateMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionPrepareMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionRollbackMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListAddMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListRemoveMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListSizeMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapContainsKeyMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapDeleteMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetForUpdateMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapIsEmptyMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetWithPredicateMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutIfAbsentMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveIfSameMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceIfSameMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSizeMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesWithPredicateMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapGetMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapPutMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveEntryMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapSizeMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapValueCountMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueOfferMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePeekMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePollMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueSizeMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueTakeMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetAddMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetRemoveMessageTask
-  
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetSizeMessageTask
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.collection.client.CollectionAddAllRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.collection.client.CollectionAddListenerRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.collection.client.CollectionAddRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.collection.client.CollectionClearRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.collection.client.CollectionCompareAndRemoveRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.collection.client.CollectionContainsRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.collection.client.CollectionGetAllRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.collection.client.CollectionIsEmptyRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.collection.client.CollectionRemoveListenerRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.collection.client.CollectionRemoveRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.collection.client.CollectionSizeRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.list.client.ListGetRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.list.client.ListIndexOfRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.list.client.ListRemoveRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.list.client.ListSetRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.list.client.ListSubRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.queue.client.AddAllRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.queue.client.AddListenerRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.queue.client.ClearRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.queue.client.CompareAndRemoveRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.queue.client.ContainsRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.queue.client.DrainRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.queue.client.IsEmptyRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.queue.client.IteratorRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.queue.client.OfferRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.queue.client.PeekRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.queue.client.PollRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.queue.client.RemainingCapacityRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.queue.client.RemoveListenerRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.queue.client.RemoveRequest
-  
- getMethodName() - Method in class com.hazelcast.collection.impl.queue.client.SizeRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.atomiclong.client.AddAndGetRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.atomiclong.client.AlterAndGetRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.atomiclong.client.AlterRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.atomiclong.client.ApplyRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.atomiclong.client.CompareAndSetRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.atomiclong.client.GetAndAddRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.atomiclong.client.GetAndAlterRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.atomiclong.client.GetAndSetRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.atomiclong.client.SetRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.atomicreference.client.AlterAndGetRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.atomicreference.client.AlterRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.atomicreference.client.ApplyRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.atomicreference.client.CompareAndSetRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.atomicreference.client.ContainsRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.atomicreference.client.GetAndAlterRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.atomicreference.client.GetAndSetRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.atomicreference.client.GetRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.atomicreference.client.IsNullRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.atomicreference.client.SetRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.lock.client.AwaitRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.lock.client.IsLockedRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.lock.client.SignalRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.semaphore.client.AcquireRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.semaphore.client.AvailableRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.semaphore.client.DrainRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.semaphore.client.InitRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.semaphore.client.ReduceRequest
-  
- getMethodName() - Method in class com.hazelcast.concurrent.semaphore.client.ReleaseRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapAddEntryListenerRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapAddIndexRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapAddPartitionLostListenerRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapClearRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapContainsKeyRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapContainsValueRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapDeleteRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapEvictAllRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapEvictRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapFlushRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapGetAllRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapGetRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapIsEmptyRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapPutAllRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapPutIfAbsentRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapPutRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapPutTransientRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapQueryRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapRemoveEntryListenerRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapRemovePartitionLostListenerRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapReplaceIfSameRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapReplaceRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapSetRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapSizeRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapTryPutRequest
-  
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-  
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-  
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.ClearRequest
-  
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.ContainsRequest
-  
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.CountRequest
-  
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.EntrySetRequest
-  
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.GetAllRequest
-  
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.KeyBasedContainsRequest
-  
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.KeySetRequest
-  
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.PutRequest
-  
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.RemoveAllRequest
-  
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.RemoveEntryListenerRequest
-  
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.RemoveRequest
-  
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.SizeRequest
-  
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.ValuesRequest
-  
- getMethodName() - Method in class com.hazelcast.partition.client.AddPartitionLostListenerRequest
-  
- getMethodName() - Method in class com.hazelcast.partition.client.RemovePartitionLostListenerRequest
-  
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
-  
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapClearRequest
-  
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsKeyRequest
-  
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsValueRequest
-  
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapEntrySetRequest
-  
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapGetRequest
-  
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapIsEmptyRequest
-  
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapKeySetRequest
-  
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-  
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutTtlRequest
-  
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-  
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveRequest
-  
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapSizeRequest
-  
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapValuesRequest
-  
- getMethodName() - Method in class com.hazelcast.ringbuffer.impl.client.AddAllRequest
-  
- getMethodName() - Method in class com.hazelcast.ringbuffer.impl.client.AddRequest
-  
- getMethodName() - Method in class com.hazelcast.ringbuffer.impl.client.CapacityRequest
-  
- getMethodName() - Method in class com.hazelcast.ringbuffer.impl.client.HeadSequenceRequest
-  
- getMethodName() - Method in class com.hazelcast.ringbuffer.impl.client.ReadManyRequest
-  
- getMethodName() - Method in class com.hazelcast.ringbuffer.impl.client.ReadOneRequest
-  
- getMethodName() - Method in class com.hazelcast.ringbuffer.impl.client.RemainingCapacityRequest
-  
- getMethodName() - Method in class com.hazelcast.ringbuffer.impl.client.SizeRequest
-  
- getMethodName() - Method in class com.hazelcast.ringbuffer.impl.client.TailSequenceRequest
-  
- getMethodName() - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-  
- getMethodName() - Method in class com.hazelcast.topic.impl.client.PublishRequest
-  
- getMethodName() - Method in class com.hazelcast.topic.impl.client.RemoveMessageListenerRequest
-  
- getMetricsId() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- getMetricsRegistry() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getMigrationData(PartitionReplicationEvent) - Method in class com.hazelcast.collection.impl.collection.CollectionService
-  
- getMigrationEndpoint() - Method in class com.hazelcast.spi.PartitionMigrationEvent
- 
Gets the partition migration endpoint. 
- getMigrationInfo() - Method in class com.hazelcast.partition.impl.BaseMigrationOperation
-  
- getMigrationQueueSize() - Method in class com.hazelcast.monitor.impl.MemberPartitionStateImpl
-  
- getMigrationQueueSize() - Method in interface com.hazelcast.monitor.MemberPartitionState
- 
Returns Migration queue size (This statistic is valid only for master) 
- getMigrationQueueSize() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getMigrationQueueSize() - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- getMillis(HazelcastProperty) - Method in class com.hazelcast.instance.HazelcastProperties
- 
- getMimeTypes() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
-  
- getMinAge() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- getMinAge() - Method in interface com.hazelcast.monitor.LocalQueueStats
- 
Returns the minimum age of the items in this member. 
- getMinBlockSize() - Method in class com.hazelcast.config.NativeMemoryConfig
-  
- getMinEvictionCheckMillis() - Method in class com.hazelcast.config.MapConfig
- 
Returns the minimum milliseconds which should pass before asking if a partition of this map is evictable or not. 
- getMinorCollectionCount() - Method in class com.hazelcast.memory.DefaultGarbageCollectorStats
-  
- getMinorCollectionCount() - Method in interface com.hazelcast.memory.GarbageCollectorStats
- 
Returns minor collection count. 
- getMinorCollectionCount() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-  
- getMinorCollectionTime() - Method in class com.hazelcast.memory.DefaultGarbageCollectorStats
-  
- getMinorCollectionTime() - Method in interface com.hazelcast.memory.GarbageCollectorStats
- 
Returns total minor collection time in ms. 
- getMinorCollectionTime() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-  
- getMisses() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-  
- getMisses() - Method in interface com.hazelcast.monitor.NearCacheStats
- 
Returns the number of misses of the locally owned entries. 
- getModifier() - Method in class com.hazelcast.query.impl.getters.AbstractMultiValueGetter
-  
- getModifierSuffix(String, String) - Static method in class com.hazelcast.query.impl.getters.SuffixModifierUtils
- 
Get modifier suffix if fullName contains any otherwise returns null. 
- getMonitor() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- getMonthSeconds() - Static method in class com.hazelcast.internal.ascii.TextCommandConstants
-  
- getMulticastConfig() - Method in class com.hazelcast.config.JoinConfig
-  
- getMulticastGroup() - Method in class com.hazelcast.config.MulticastConfig
- 
Gets the multicast group. 
- getMulticastPort() - Method in class com.hazelcast.config.MulticastConfig
- 
Gets the multicast port. 
- getMulticastTimeoutSeconds() - Method in class com.hazelcast.config.MulticastConfig
- 
Gets the multicast timeout in seconds. 
- getMulticastTimeToLive() - Method in class com.hazelcast.config.MulticastConfig
- 
Gets the time to live for the multicast package. 
- getMultiMap() - Method in class com.hazelcast.client.console.ClientConsoleApp
-  
- getMultiMap(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getMultiMap(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getMultiMap(String) - Method in class com.hazelcast.client.proxy.txn.TransactionContextProxy
-  
- getMultiMap(String) - Method in class com.hazelcast.client.proxy.txn.xa.XATransactionContextProxy
-  
- getMultiMap(String) - Method in class com.hazelcast.client.txn.proxy.xa.XATransactionContextProxy
-  
- getMultiMap(String) - Method in class com.hazelcast.client.txn.TransactionContextProxy
-  
- getMultiMap() - Method in class com.hazelcast.console.ConsoleApp
-  
- getMultiMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the distributed multimap instance with the specified name. 
- getMultiMap(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getMultiMap(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getMultiMap(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getMultiMap(String) - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
-  
- getMultiMap(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
- 
Returns the transactional multimap instance with the specified name. 
- getMultiMapConfig(String) - Method in class com.hazelcast.config.Config
-  
- getMultiMapConfigs() - Method in class com.hazelcast.config.Config
-  
- getMultiMapName() - Method in class com.hazelcast.mapreduce.impl.MultiMapKeyValueSource
-  
- getMultiMapValueOrNull() - Method in class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-  
- getMXBeans() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- getMXBeans() - Method in interface com.hazelcast.monitor.MemberState
-  
- getName() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- getName() - Method in class com.hazelcast.cache.impl.CacheDistributedObject
-  
- getName() - Method in interface com.hazelcast.cache.impl.CacheEventData
- 
Gets the name of the cache. 
- getName() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-  
- getName() - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- getName() - Method in class com.hazelcast.cache.impl.client.CacheInvalidationMessage
-  
- getName() - Method in class com.hazelcast.cache.impl.event.AbstractICacheEvent
- 
Returns the name of the cache for this event. 
- getName() - Method in interface com.hazelcast.cache.impl.event.ICacheEvent
- 
Returns the name of the cache for this event. 
- getName() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Gets the name of the distributed object name of the cache. 
- getName() - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache
-  
- getName() - Method in interface com.hazelcast.cache.impl.nearcache.NearCache
- 
Gets the name of the  thisNearCache instance. 
- getName() - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- getName() - Method in enum com.hazelcast.client.config.ClientProperty
-  
- getName() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
- 
Gets the name of the reliable topic. 
- getName() - Method in class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
-  
- getName() - Method in class com.hazelcast.client.impl.client.DistributedObjectInfo
-  
- getName() - Method in class com.hazelcast.client.impl.client.GenericError
-  
- getName() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getName() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getName() - Method in class com.hazelcast.client.map.impl.nearcache.ClientHeapNearCache
-  
- getName() - Method in class com.hazelcast.client.spi.ClientProxy
-  
- getName() - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-  
- getName() - Method in class com.hazelcast.collection.impl.collection.CollectionEvent
-  
- getName() - Method in class com.hazelcast.collection.impl.queue.operations.QueueOperation
-  
- getName() - Method in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
-  
- getName() - Method in class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxySupport
-  
- getName() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- getName() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- getName() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
-  
- getName() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
-  
- getName() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorImpl
-  
- getName() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorProxy
-  
- getName() - Method in class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-  
- getName() - Method in class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-  
- getName() - Method in class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-  
- getName() - Method in class com.hazelcast.concurrent.lock.LockProxy
-  
- getName() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-  
- getName() - Method in class com.hazelcast.config.CacheConfig
- 
- getName() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
- getName() - Method in class com.hazelcast.config.CollectionConfig
- 
Gets the name of this collection. 
- getName() - Method in class com.hazelcast.config.ExecutorConfig
- 
Gets the name of the executor task. 
- getName() - Method in class com.hazelcast.config.GroupConfig
- 
Gets the group name of the group. 
- getName() - Method in class com.hazelcast.config.JobTrackerConfig
- 
- getName() - Method in class com.hazelcast.config.MapAttributeConfig
- 
Gets the name of the attribute extracted by the extractor. 
- getName() - Method in class com.hazelcast.config.MapConfig
- 
Returns the name of this  IMap
- getName() - Method in class com.hazelcast.config.MultiMapConfig
- 
Gets the name of this MultiMap. 
- getName() - Method in class com.hazelcast.config.NearCacheConfig
- 
Gets the name of the near cache. 
- getName() - Method in class com.hazelcast.config.PermissionConfig
-  
- getName() - Method in class com.hazelcast.config.QueryCacheConfig
- 
Returns the name of QueryCache.
 
- getName() - Method in class com.hazelcast.config.QueueConfig
-  
- getName() - Method in class com.hazelcast.config.QuorumConfig
-  
- getName() - Method in class com.hazelcast.config.ReliableTopicConfig
- 
Gets the name of the reliable topic. 
- getName() - Method in class com.hazelcast.config.ReplicatedMapConfig
- 
- getName() - Method in class com.hazelcast.config.RingbufferConfig
- 
Returns the name of the ringbuffer. 
- getName() - Method in class com.hazelcast.config.SemaphoreConfig
- 
Gets the name of the semaphore. 
- getName() - Method in class com.hazelcast.config.ServiceConfig
-  
- getName() - Method in class com.hazelcast.config.TopicConfig
- 
Gets the name of the topic, null if nothing is set. 
- getName() - Method in class com.hazelcast.config.WanReplicationConfig
-  
- getName() - Method in class com.hazelcast.config.WanReplicationRef
-  
- getName() - Method in class com.hazelcast.core.AbstractIMapEvent
- 
Returns the name of the map for this event. 
- getName() - Method in interface com.hazelcast.core.DistributedObject
- 
Returns the unique name for this DistributedObject. 
- getName() - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the name of this Hazelcast instance 
- getName() - Method in interface com.hazelcast.core.IAtomicLong
- 
Returns the name of this IAtomicLong instance. 
- getName() - Method in interface com.hazelcast.core.ICollection
- 
Returns the name of this collection. 
- getName() - Method in interface com.hazelcast.core.IMapEvent
- 
Returns the name of the map for this event. 
- getName() - Method in interface com.hazelcast.core.ISemaphore
- 
Returns the name of this ISemaphore instance. 
- getName() - Method in interface com.hazelcast.core.ITopic
- 
Returns the name of this ITopic instance 
- getName() - Method in interface com.hazelcast.core.MultiMap
- 
Returns the name of this multimap. 
- getName() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- getName() - Method in enum com.hazelcast.instance.GroupProperty
-  
- getName() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getName() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getName() - Method in interface com.hazelcast.instance.HazelcastProperty
- 
Returns the property name. 
- getName() - Method in interface com.hazelcast.internal.metrics.Metric
- 
Gets the name that identifies this metric. 
- getName() - Method in class com.hazelcast.internal.serialization.impl.FieldDefinitionImpl
-  
- getName() - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getName() - Method in class com.hazelcast.jmx.AtomicLongMBean
-  
- getName() - Method in class com.hazelcast.jmx.AtomicReferenceMBean
-  
- getName() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getName() - Method in class com.hazelcast.jmx.ListMBean
-  
- getName() - Method in class com.hazelcast.jmx.LockMBean
-  
- getName() - Method in class com.hazelcast.jmx.ManagedExecutorServiceMBean
-  
- getName() - Method in class com.hazelcast.jmx.MapMBean
-  
- getName() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getName() - Method in class com.hazelcast.jmx.NodeMBean
-  
- getName() - Method in class com.hazelcast.jmx.QueueMBean
-  
- getName() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- getName() - Method in class com.hazelcast.jmx.SemaphoreMBean
-  
- getName() - Method in class com.hazelcast.jmx.SetMBean
-  
- getName() - Method in class com.hazelcast.jmx.TopicMBean
-  
- getName() - Method in class com.hazelcast.map.impl.MapContainer
-  
- getName() - Method in class com.hazelcast.map.impl.nearcache.Invalidation
-  
- getName() - Method in class com.hazelcast.map.impl.nearcache.NearCacheImpl
-  
- getName() - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperation
-  
- getName() - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
-  
- getName() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- getName() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-  
- getName() - Method in interface com.hazelcast.map.QueryCache
- 
Returns the name of this QueryCache.
 
- getName() - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-  
- getName() - Method in class com.hazelcast.mapreduce.impl.notification.MapReduceNotification
-  
- getName() - Method in class com.hazelcast.mapreduce.impl.operation.ProcessingOperation
-  
- getName() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-  
- getName() - Method in class com.hazelcast.mapreduce.impl.task.MapCombineTask
-  
- getName() - Method in class com.hazelcast.mapreduce.impl.task.ReducerTask
-  
- getName() - Method in class com.hazelcast.mapreduce.impl.task.TrackableJobFuture
-  
- getName() - Method in interface com.hazelcast.mapreduce.TrackableJob
- 
- getName() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-  
- getName() - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
-  
- getName() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
-  
- getName() - Method in class com.hazelcast.quorum.impl.QuorumImpl
-  
- getName() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-  
- getName() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- getName() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-  
- getName() - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
-  
- getName() - Method in class com.hazelcast.spi.impl.AbstractNamedOperation
-  
- getName() - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
-  
- getName() - Method in class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectEventPacket
-  
- getName() - Method in class com.hazelcast.spi.impl.servicemanager.ServiceInfo
-  
- getName() - Method in interface com.hazelcast.spi.NamedOperation
- 
Returns the name of the distributed data structure. 
- getName() - Method in class com.hazelcast.spring.cache.HazelcastCache
-  
- getName() - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicProxy
-  
- getName() - Method in class com.hazelcast.topic.impl.TopicProxySupport
-  
- getName() - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
-  
- getName() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-  
- getName() - Method in interface com.hazelcast.util.executor.ManagedExecutorService
-  
- getName() - Method in class com.hazelcast.util.executor.NamedThreadPoolExecutor
-  
- getNameAsPartitionAwareData() - Method in class com.hazelcast.spi.AbstractDistributedObject
-  
- getNames() - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
-  
- getNames() - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
- 
Gets a set of all current probe names. 
- getNames() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
-  
- getNamespace() - Method in class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-  
- getNamespace() - Method in class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-  
- getNamespace() - Method in class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-  
- getNamespace() - Method in class com.hazelcast.concurrent.lock.client.IsLockedRequest
-  
- getNamespace() - Method in class com.hazelcast.concurrent.lock.client.LockRequest
-  
- getNamespace() - Method in class com.hazelcast.concurrent.lock.client.UnlockRequest
-  
- getNamespace() - Method in class com.hazelcast.concurrent.lock.LockProxySupport
-  
- getNamespace() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- getNamespace() - Method in class com.hazelcast.map.impl.client.MapIsLockedRequest
-  
- getNamespace() - Method in class com.hazelcast.map.impl.client.MapLockRequest
-  
- getNamespace() - Method in class com.hazelcast.map.impl.client.MapUnlockRequest
-  
- getNamespace() - Method in class com.hazelcast.multimap.impl.client.MultiMapIsLockedRequest
-  
- getNamespace() - Method in class com.hazelcast.multimap.impl.client.MultiMapLockRequest
-  
- getNamespace() - Method in class com.hazelcast.multimap.impl.client.MultiMapUnlockRequest
-  
- getNamespaceType() - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-  
- getNameWithPrefix() - Method in class com.hazelcast.config.CacheConfig
- 
Gets the full name of the  ICache, including the manager scope prefix. 
- getNanos(HazelcastProperty) - Method in class com.hazelcast.instance.HazelcastProperties
- 
- getNativeCache() - Method in class com.hazelcast.spring.cache.HazelcastCache
-  
- getNativeMemoryConfig() - Method in class com.hazelcast.client.config.ClientConfig
-  
- getNativeMemoryConfig() - Method in class com.hazelcast.config.Config
-  
- getNearCache(String) - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCacheManager
-  
- getNearCache(String) - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheManager
- 
Gets the  NearCache instance
 associated with given  name. 
- getNearCache() - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- getNearCache() - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- getNearCache() - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- getNearCacheConfig(String) - Method in class com.hazelcast.client.config.ClientConfig
- 
- getNearCacheConfig() - Method in class com.hazelcast.config.MapConfig
- 
Returns the near cache configuration 
- getNearCacheConfig() - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- getNearCacheConfigMap() - Method in class com.hazelcast.client.config.ClientConfig
- 
Map of all configured NearCacheConfig's with the name key and configuration as the value 
- getNearCacheExecutor() - Method in class com.hazelcast.cache.impl.nearcache.NearCacheContext
-  
- getNearCacheInvalidator() - Method in class com.hazelcast.map.impl.nearcache.NearCacheProvider
-  
- getNearCacheManager() - Method in class com.hazelcast.cache.impl.nearcache.NearCacheContext
-  
- getNearCacheManager() - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
- 
- getNearCacheManager() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getNearCacheManager() - Method in class com.hazelcast.client.spi.ClientContext
-  
- getNearCacheProvider() - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- getNearCacheSizeEstimator() - Method in class com.hazelcast.map.impl.MapContainer
-  
- getNearCacheSizeEstimator() - Method in class com.hazelcast.map.impl.nearcache.NearCacheImpl
-  
- getNearCacheStatistics() - Method in interface com.hazelcast.cache.CacheStatistics
- 
Gets the near-cache statistics. 
- getNearCacheStatistics() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- getNearCacheStatistics() - Method in class com.hazelcast.client.cache.impl.ClientCacheStatisticsImpl
-  
- getNearCacheStats() - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache
-  
- getNearCacheStats() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- getNearCacheStats() - Method in interface com.hazelcast.cache.impl.nearcache.NearCache
- 
- getNearCacheStats() - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheRecordStore
- 
- getNearCacheStats() - Method in class com.hazelcast.client.map.impl.nearcache.ClientHeapNearCache
-  
- getNearCacheStats() - Method in class com.hazelcast.map.impl.nearcache.NearCacheImpl
-  
- getNearCacheStats() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getNearCacheStats() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getNearCacheStats() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns statistics related to the Near Cache. 
- getNearestAnchorEntry(PagingPredicate) - Static method in class com.hazelcast.query.PagingPredicateAccessor
-  
- getNetworkConfig() - Method in class com.hazelcast.client.config.ClientConfig
- 
- getNetworkConfig() - Method in class com.hazelcast.config.Config
-  
- getNewAddress() - Method in class com.hazelcast.partition.impl.PartitionReplicaChangeEvent
-  
- getNewOwner() - Method in class com.hazelcast.core.MigrationEvent
- 
Returns the new owner of the migrating partition 
- getNewValueData() - Method in class com.hazelcast.map.impl.DataAwareEntryEvent
-  
- getNextRecordId() - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
-  
- getNode() - Method in interface com.hazelcast.internal.ascii.TextCommandService
-  
- getNode() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- getNode() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getNode() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getNodeEngine() - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- getNodeEngine() - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- getNodeEngine() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- getNodeEngine() - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- getNodeEngine() - Method in class com.hazelcast.instance.Node
-  
- getNodeEngine() - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- getNodeEngine() - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-  
- getNodeEngine() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-  
- getNodeEngine() - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- getNodeEngine() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- getNodeEngine() - Method in class com.hazelcast.spi.AbstractDistributedObject
- 
Gets the node engine. 
- getNodeEngine() - Method in class com.hazelcast.spi.Operation
-  
- getNodeExtension() - Method in class com.hazelcast.instance.Node
-  
- getNodeFilter() - Method in class com.hazelcast.config.DiscoveryConfig
-  
- getNodeFilterClass() - Method in class com.hazelcast.config.DiscoveryConfig
-  
- getNodeMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getNodeName() - Method in enum com.hazelcast.config.PermissionConfig.PermissionType
-  
- getNormalFramesReadCounter() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingSocketReader
-  
- getNormalFramesReadCounter() - Method in interface com.hazelcast.nio.tcp.SocketReader
- 
Gets the Counter that counts the number of normal packets that have been read. 
- getNormalFramesReadCounter() - Method in class com.hazelcast.nio.tcp.spinning.SpinningSocketReader
-  
- getNotificationInfo() - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-  
- getNotifiedKey() - Method in class com.hazelcast.collection.impl.queue.operations.AddAllOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.collection.impl.queue.operations.ClearOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.collection.impl.queue.operations.DrainOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.collection.impl.queue.operations.RemoveOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
-  
- getNotifiedKey() - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
-  
- getNotifiedKey() - Method in interface com.hazelcast.spi.Notifier
-  
- getNotLockedRecords() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- getNow() - Method in class com.hazelcast.map.impl.query.MapQueryEngineImpl
-  
- getNumberOfAffectedEntries() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-  
- getNumberOfAffectedEntries() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-  
- getNumberOfEntries() - Method in class com.hazelcast.map.impl.event.MapEventData
-  
- getNumberOfEntriesAffected() - Method in class com.hazelcast.core.MapEvent
- 
Returns the number of entries affected by this event. 
- getObject() - Method in class com.hazelcast.multimap.impl.MultiMapRecord
-  
- getObject(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
- 
Returns a field in a Json object as an object. 
- getObject(JsonObject, String, JsonObject) - Static method in class com.hazelcast.util.JsonUtil
- 
Returns a field in a Json object as an object. 
- getObjectCollection(NodeEngine) - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
-  
- getObjectEntrySet(NodeEngine) - Method in class com.hazelcast.multimap.impl.operations.EntrySetResponse
-  
- getObjectId() - Method in class com.hazelcast.core.DistributedObjectEvent
- 
- getObjectName() - Method in class com.hazelcast.concurrent.lock.ConditionKey
-  
- getObjectName() - Method in class com.hazelcast.concurrent.lock.InternalLockNamespace
-  
- getObjectName() - Method in class com.hazelcast.concurrent.lock.LockWaitNotifyKey
-  
- getObjectName() - Method in class com.hazelcast.core.DistributedObjectEvent
- 
Returns the name of related DistributedObject. 
- getObjectName() - Method in class com.hazelcast.spi.AbstractWaitNotifyKey
-  
- getObjectName() - Method in class com.hazelcast.spi.DefaultObjectNamespace
-  
- getObjectName() - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyInfo
-  
- getObjectName() - Method in interface com.hazelcast.spi.ObjectNamespace
- 
Gets the object name within the service. 
- getObjectName() - Method in interface com.hazelcast.spi.WaitNotifyKey
- 
Returns the object name of the wait notify object for this key. 
- getOfferOperationCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- getOfferOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
- 
Returns the number of offer/put/add operations. 
- getOfferWaitNotifyKey() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- getOldAddress() - Method in class com.hazelcast.partition.impl.PartitionReplicaChangeEvent
-  
- getOldOwner() - Method in class com.hazelcast.core.MigrationEvent
- 
Returns the old owner of the migrating partition 
- getOldValue() - Method in class com.hazelcast.cache.impl.CacheEntryEventImpl
-  
- getOldValue() - Method in class com.hazelcast.core.EntryEvent
- 
Returns the old value of the entry event. 
- getOldValue() - Method in class com.hazelcast.map.impl.DataAwareEntryEvent
-  
- getOldValue() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-  
- getOldValue() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-  
- getOldValueData() - Method in class com.hazelcast.map.impl.DataAwareEntryEvent
-  
- getOngoingReplicaSyncRequests() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getOp() - Method in class com.hazelcast.spi.InvocationBuilder
- 
Gets the operation to execute. 
- GetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-  
- GetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetOperation
-  
- GetOperation(String) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetOperation
-  
- GetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-  
- GetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetOperation
-  
- GetOperation(String) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetOperation
-  
- GetOperation - Class in com.hazelcast.map.impl.operation
-  
- GetOperation() - Constructor for class com.hazelcast.map.impl.operation.GetOperation
-  
- GetOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.GetOperation
-  
- GetOperation - Class in com.hazelcast.replicatedmap.impl.operation
-  
- GetOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.GetOperation
-  
- GetOperation(String, Data) - Constructor for class com.hazelcast.replicatedmap.impl.operation.GetOperation
-  
- getOperationExecutor() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- getOperationExecutorQueueSize() - Method in class com.hazelcast.spi.impl.operationexecutor.classic.ClassicOperationExecutor
-  
- getOperationExecutorQueueSize() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
- 
Deprecated. 
- getOperationExecutorQueueSize() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- getOperationExecutorQueueSize() - Method in interface com.hazelcast.spi.OperationService
- 
Deprecated. 
- getOperationProvider() - Method in class com.hazelcast.cache.impl.client.AbstractCacheRequest
-  
- getOperationProvider(String) - Method in class com.hazelcast.client.impl.protocol.task.cache.AbstractCacheMessageTask
-  
- getOperationProvider() - Method in class com.hazelcast.map.impl.client.MapAllPartitionsClientRequest
-  
- getOperationProvider() - Method in class com.hazelcast.map.impl.client.MapPartitionClientRequest
-  
- getOperationProvider(String) - Method in class com.hazelcast.map.impl.operation.MapOperationProviders
- 
- getOperationProvider(MapConfig) - Method in class com.hazelcast.map.impl.operation.MapOperationProviders
- 
Returns a  MapOperationProvider instance, depending on whether the provided  MapConfig has a
 WAN replication policy configured or not. 
- getOperationResponseHandler() - Method in class com.hazelcast.spi.Operation
- 
Gets the OperationResponseHandler tied to this Operation. 
- getOperationRunner(int) - Method in class com.hazelcast.spi.impl.operationexecutor.classic.GenericOperationThread
-  
- getOperationRunner(int) - Method in class com.hazelcast.spi.impl.operationexecutor.classic.OperationThread
-  
- getOperationRunner(int) - Method in class com.hazelcast.spi.impl.operationexecutor.classic.PartitionOperationThread
- 
- getOperationService() - Method in class com.hazelcast.spi.AbstractDistributedObject
- 
Gets the OperationService. 
- getOperationService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getOperationService() - Method in interface com.hazelcast.spi.NodeEngine
- 
Gets the OperationService. 
- getOperationServiceBean() - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
-  
- getOperationServiceMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getOperationStats() - Method in class com.hazelcast.internal.management.TimedMemberStateFactory
-  
- getOperationStats() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- getOperationStats() - Method in interface com.hazelcast.monitor.MemberState
- 
Returns the local operation statistics. 
- getOperationThreadCount() - Method in class com.hazelcast.jmx.OperationServiceMBean
-  
- getOperationType() - Method in class com.hazelcast.cluster.client.MemberAttributeChange
-  
- getOperationType() - Method in class com.hazelcast.core.MemberAttributeEvent
- 
Returns the type of member attribute change for this MemberAttributeEvent. 
- getOrConnect(Address, boolean) - Method in interface com.hazelcast.client.connection.ClientConnectionManager
-  
- getOrConnect(Address, boolean) - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-  
- getOrConnect(Address) - Method in interface com.hazelcast.nio.ConnectionManager
- 
Gets the existing connection for a given address or connects. 
- getOrConnect(Address, boolean) - Method in interface com.hazelcast.nio.ConnectionManager
- 
Gets the existing connection for a given address. 
- getOrConnect(Address) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- getOrConnect(Address, boolean) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- getOrCreateCache(String, CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- getOrCreateCacheContext(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- getOrCreateCacheContext(String) - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- getOrCreateCollectionContainer(int, String) - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- getOrCreateCombiner(KeyIn) - Method in class com.hazelcast.mapreduce.impl.task.DefaultContext
-  
- getOrCreateContainer(String, boolean) - Method in class com.hazelcast.collection.impl.collection.CollectionService
-  
- getOrCreateContainer() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
-  
- getOrCreateContainer(String, boolean) - Method in class com.hazelcast.collection.impl.list.ListService
-  
- getOrCreateContainer() - Method in class com.hazelcast.collection.impl.queue.operations.QueueOperation
-  
- getOrCreateContainer(String, boolean) - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- getOrCreateContainer(String, boolean) - Method in class com.hazelcast.collection.impl.set.SetService
-  
- getOrCreateContainer() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-  
- getOrCreateContext(MapCombineTask) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-  
- getOrCreateHazelcastInstance(Config) - Static method in class com.hazelcast.core.Hazelcast
- 
Gets or creates the HazelcastInstance with a certain name. 
- getOrCreateHazelcastInstance(Config) - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
-  
- getOrCreateHazelcastSession() - Method in class com.hazelcast.web.WebFilter.RequestWrapper
-  
- getOrCreateList(List<EventRegistration>) - Method in class com.hazelcast.map.impl.event.MapEventPublisherImpl
-  
- getOrCreateListContainer() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
-  
- getOrCreateMultiMapContainer(String) - Method in class com.hazelcast.multimap.impl.MultiMapPartitionContainer
-  
- getOrCreateMultiMapValue() - Method in class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-  
- getOrCreateNearCache(String, NearCacheConfig, NearCacheContext) - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCacheManager
-  
- getOrCreateNearCache(String, NearCacheConfig, NearCacheContext) - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheManager
- 
Creates a new  NearCache with given configurations
 or returns existing one. 
- getOrCreateNearCache(String) - Method in class com.hazelcast.map.impl.nearcache.NearCacheProvider
-  
- getOrCreateProxy(String, String) - Method in class com.hazelcast.client.spi.ProxyManager
-  
- getOrCreateRecordStore(String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- getOrCreateRecordStore(String) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-  
- getOrCreateRecordStore(String, int) - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- getOrCreateRecordStore(String) - Method in class com.hazelcast.replicatedmap.impl.PartitionContainer
-  
- getOrCreateRegistry(String) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-  
- getOrDefault(PropertyDefinition, T) - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
- 
Returns the value of the requested  PropertyDefinition if available in the
 declarative or programmatic configuration (XML or Config API), otherwise it will
 return the given  defaultValue. 
- getOrDefault(String, PropertyDefinition, T) - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
- 
Returns the value of the requested  PropertyDefinition if available in the
 declarative or programmatic configuration (XML or Config API), can be found in the
 system's environment, or passed as a JVM property. 
- getOrderKey() - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- getOrderKey(String, Invalidation) - Static method in class com.hazelcast.map.impl.nearcache.AbstractNearCacheInvalidator
-  
- getOrderLock(String) - Method in class com.hazelcast.topic.impl.TopicService
-  
- getOrigin() - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- getOriginalSession() - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- getOriginalSessionId() - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- getOriginClassName() - Method in exception com.hazelcast.client.UndefinedErrorCodeException
-  
- getOrNull(PropertyDefinition) - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
- 
Returns the value of the requested  PropertyDefinition if available in the
 declarative or programmatic configuration (XML or Config API), otherwise it will
 return  null. 
- getOrNull(String, PropertyDefinition) - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
- 
Returns the value of the requested  PropertyDefinition if available in the
 declarative or programmatic configuration (XML or Config API), can be found in the
 system's environment, or passed as a JVM property. 
- getOrPutIfAbsent(ConcurrentMap<K, V>, K, ConstructorFunction<K, V>) - Static method in class com.hazelcast.util.ConcurrencyUtil
-  
- getOrPutSynchronized(ConcurrentMap<K, V>, K, Object, ConstructorFunction<K, V>) - Static method in class com.hazelcast.util.ConcurrencyUtil
-  
- getOrPutSynchronized(ConcurrentMap<K, V>, K, ContextMutexFactory, ConstructorFunction<K, V>) - Static method in class com.hazelcast.util.ConcurrencyUtil
-  
- getOrTriggerConnect(Address, boolean) - Method in interface com.hazelcast.client.connection.ClientConnectionManager
-  
- getOrTriggerConnect(Address, boolean) - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-  
- getOtherOperationCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getOtherOperationCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getOtherOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns the total number of Other Operations 
- getOtherOperationsCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- getOtherOperationsCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
- 
Returns number of other operations 
- getOutboundPortDefinitions() - Method in class com.hazelcast.config.NetworkConfig
-  
- getOutboundPorts() - Method in class com.hazelcast.config.NetworkConfig
-  
- getOutboundPorts() - Method in interface com.hazelcast.nio.IOService
-  
- getOutboundPorts() - Method in class com.hazelcast.nio.NodeIOService
-  
- getOutboundQueueSize() - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
-  
- getOutboundQueueSize() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
- 
Returns the outbound queue size on this member 
- getOutOfMemoryErrorCount() - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
- 
Gets the number of OutOfMemoryErrors that have been reported. 
- getOutputSelectorThreadCount() - Method in interface com.hazelcast.nio.IOService
-  
- getOutputSelectorThreadCount() - Method in class com.hazelcast.nio.NodeIOService
-  
- getOutputStatement(String) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
-  
- getOutputThreads() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingIOThreadingModel
-  
- getOwnedEntryCount() - Method in interface com.hazelcast.cache.CacheStatistics
- 
Returns the owned entry count in the cache. 
- getOwnedEntryCount() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- getOwnedEntryCount() - Method in class com.hazelcast.client.cache.impl.ClientCacheStatisticsImpl
-  
- getOwnedEntryCount() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-  
- getOwnedEntryCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getOwnedEntryCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getOwnedEntryCount() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-  
- getOwnedEntryCount() - Method in interface com.hazelcast.monitor.LocalCacheStats
- 
Returns the owned entry count in the cache. 
- getOwnedEntryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns the number of entries owned by this member. 
- getOwnedEntryCount() - Method in interface com.hazelcast.monitor.NearCacheStats
- 
Returns the number of entries owned by this member. 
- getOwnedEntryMemoryCost() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getOwnedEntryMemoryCost() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getOwnedEntryMemoryCost() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-  
- getOwnedEntryMemoryCost() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns memory cost (number of bytes) of owned entries in this member. 
- getOwnedEntryMemoryCost() - Method in interface com.hazelcast.monitor.NearCacheStats
- 
Returns memory cost (number of bytes) of entries in this cache. 
- getOwnedItemCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- getOwnedItemCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
- 
Returns the number of owned items in this member. 
- getOwnedPartitions() - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- getOwner() - Method in interface com.hazelcast.concurrent.lock.LockResource
-  
- getOwner() - Method in interface com.hazelcast.core.Partition
- 
Returns the current member that owns this partition. 
- getOwner() - Method in class com.hazelcast.mapreduce.impl.task.JobPartitionStateImpl
-  
- getOwner() - Method in interface com.hazelcast.mapreduce.JobPartitionState
- 
Returns the owner of this partition 
- getOwner() - Method in class com.hazelcast.nio.tcp.nonblocking.AbstractHandler
-  
- getOwner() - Method in interface com.hazelcast.nio.tcp.nonblocking.MigratableHandler
- 
Get NonBlockingIOThread currently owning this handler. 
- getOwner() - Method in class com.hazelcast.partition.PartitionServiceProxy.PartitionProxy
-  
- getOwnerBundle() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
- 
Gets the owner Bundleof this instance.
 
- getOwnerConnectionAddress() - Method in interface com.hazelcast.client.spi.ClientClusterService
- 
The owner connection is opened to owner member of the client in the cluster. 
- getOwnerConnectionAddress() - Method in class com.hazelcast.client.spi.impl.ClusterListenerSupport
-  
- getOwnerIndexes() - Method in class com.hazelcast.partition.client.PartitionsResponse
-  
- getOwnerInfo(Data) - Method in interface com.hazelcast.concurrent.lock.LockStore
-  
- getOwnerInfo(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- getOwnerInfo(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
-  
- getOwnerOrNull() - Method in interface com.hazelcast.partition.InternalPartition
- 
Returns the Address of the owner of this partition. 
- getOwnerService() - Method in interface com.hazelcast.osgi.HazelcastOSGiInstance
- 
- getOwnerUuid() - Method in class com.hazelcast.client.impl.client.ClientPrincipal
-  
- getOwnerUuid() - Method in interface com.hazelcast.transaction.impl.Transaction
-  
- getOwnerUuid() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-  
- getOwnerUuid() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
-  
- getOwnerUuid() - Method in class com.hazelcast.transaction.impl.xa.XATransactionDTO
-  
- getPacketDispatcher() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getPacketVersion() - Method in class com.hazelcast.cluster.impl.JoinMessage
-  
- getPage() - Method in class com.hazelcast.query.PagingPredicate
-  
- getPageSize() - Method in class com.hazelcast.config.NativeMemoryConfig
-  
- getPageSize() - Method in class com.hazelcast.query.PagingPredicate
-  
- getParameter(String) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
-  
- getParameters() - Method in class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
-  
- getParameters() - Method in class com.hazelcast.cache.impl.client.CacheClearRequest
-  
- getParameters() - Method in class com.hazelcast.cache.impl.client.CacheContainsKeyRequest
-  
- getParameters() - Method in class com.hazelcast.cache.impl.client.CacheEntryProcessorRequest
-  
- getParameters() - Method in class com.hazelcast.cache.impl.client.CacheGetAllRequest
-  
- getParameters() - Method in class com.hazelcast.cache.impl.client.CacheGetAndRemoveRequest
-  
- getParameters() - Method in class com.hazelcast.cache.impl.client.CacheGetRequest
-  
- getParameters() - Method in class com.hazelcast.cache.impl.client.CacheIterateRequest
-  
- getParameters() - Method in class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
-  
- getParameters() - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-  
- getParameters() - Method in class com.hazelcast.cache.impl.client.CachePutAllRequest
-  
- getParameters() - Method in class com.hazelcast.cache.impl.client.CachePutIfAbsentRequest
-  
- getParameters() - Method in class com.hazelcast.cache.impl.client.CachePutRequest
-  
- getParameters() - Method in class com.hazelcast.cache.impl.client.CacheRemoveEntryListenerRequest
-  
- getParameters() - Method in class com.hazelcast.cache.impl.client.CacheRemoveRequest
-  
- getParameters() - Method in class com.hazelcast.cache.impl.client.CacheReplaceRequest
-  
- getParameters() - Method in class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
-  
- getParameters() - Method in class com.hazelcast.client.impl.client.ClientRequest
-  
- getParameters() - Method in interface com.hazelcast.client.impl.client.SecureRequest
- 
Used for  SecurityInterceptor
 Parameters passed to the method by a distributedObject
 for map.put(key, value) parameters should be 'key' and 'value'
 parameters can be in binary or object form, underlying implementation will de-serialize lazily 
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.AbstractRemoveListenerMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAddAndGetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterAndGetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongApplyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongCompareAndSetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongDecrementAndGetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAddMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAlterMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndIncrementMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndSetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongIncrementAndGetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongSetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterAndGetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceApplyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceClearMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceCompareAndSetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceContainsMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndAlterMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndSetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceIsNullMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetAndGetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationCustomCredentialsMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.AbstractCacheMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddEntryListenerMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddInvalidationListenerTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheContainsKeyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheCreateConfigMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEntryProcessorMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndRemoveMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheIterateMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutIfAbsentMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheReplaceMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionAwaitMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionBeforeAwaitMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchAwaitMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchCountDownMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchGetCountMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchTrySetCountMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.AbstractExecutorServiceCancelMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllWithIndexMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddListenerMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddWithIndexMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListClearMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRemoveAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRetainAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIndexOfMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIsEmptyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIteratorMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListLastIndexOfMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListListIteratorMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveWithIndexMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSizeMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSubMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockForceUnlockMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockGetLockCountMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockGetRemainingLeaseTimeMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockIsLockedByCurrentThreadMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockIsLockedMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockLockMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockTryLockMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockUnlockMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyWithPredicateMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerWithPredicateMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddIndexMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddInterceptorMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddNearCacheEntryListenerMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearNearCacheMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsKeyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsValueMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapDeleteMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPagingPredicateMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPredicateMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntrySetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnAllKeysMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeysMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteWithPredicateMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetEntryViewMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPagingPredicateMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutTransientMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveIfSameMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveInterceptorMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapReplaceIfSameMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapReplaceMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSizeMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSubmitToKeyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryLockMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryPutMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryRemoveMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapUnlockMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPagingPredicateMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPredicateMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.AbstractMapReduceTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceCancelMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceJobProcessInformationMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerToKeyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapClearMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsEntryMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsKeyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsValueMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapGetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapPutMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValueCountMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.NoSuchMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueClearMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRemoveAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRetainAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMaxSizeMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIsEmptyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIteratorMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueOfferMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePeekMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePollMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePutMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemainingCapacityMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueSizeMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueTakeMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerWithPredicateMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddNearCacheListenerMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsKeyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsValueMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapEntrySetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapIsEmptyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapKeySetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapSizeMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapValuesMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferCapacityMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferHeadSequenceMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadManyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadOneMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferRemainingCapacityMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferSizeMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferTailSequenceMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreAcquireMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreAvailablePermitsMessageTasks
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreDrainPermitsMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreInitMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreReducePermitsMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreReleaseMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreTryAcquireMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddListenerMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetClearMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRemoveAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRetainAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetGetAllMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetIsEmptyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.set.SetSizeMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicAddMessageListenerMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicPublishMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCommitMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCreateMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionRollbackMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAClearRemoteTransactionMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XACollectTransactionsMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAFinalizeTransactionMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCommitMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCreateMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionPrepareMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionRollbackMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListAddMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListRemoveMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListSizeMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapContainsKeyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapDeleteMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetForUpdateMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapIsEmptyMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetWithPredicateMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutIfAbsentMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveIfSameMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceIfSameMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSizeMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesWithPredicateMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapGetMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapPutMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveEntryMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapSizeMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapValueCountMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueOfferMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePeekMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePollMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueSizeMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueTakeMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetAddMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetRemoveMessageTask
-  
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetSizeMessageTask
-  
- getParameters() - Method in class com.hazelcast.collection.impl.collection.client.CollectionAddAllRequest
-  
- getParameters() - Method in class com.hazelcast.collection.impl.collection.client.CollectionAddListenerRequest
-  
- getParameters() - Method in class com.hazelcast.collection.impl.collection.client.CollectionAddRequest
-  
- getParameters() - Method in class com.hazelcast.collection.impl.collection.client.CollectionCompareAndRemoveRequest
-  
- getParameters() - Method in class com.hazelcast.collection.impl.collection.client.CollectionContainsRequest
-  
- getParameters() - Method in class com.hazelcast.collection.impl.collection.client.CollectionRemoveRequest
-  
- getParameters() - Method in class com.hazelcast.collection.impl.list.client.ListAddAllRequest
-  
- getParameters() - Method in class com.hazelcast.collection.impl.list.client.ListAddRequest
-  
- getParameters() - Method in class com.hazelcast.collection.impl.list.client.ListGetRequest
-  
- getParameters() - Method in class com.hazelcast.collection.impl.list.client.ListIndexOfRequest
-  
- getParameters() - Method in class com.hazelcast.collection.impl.list.client.ListRemoveRequest
-  
- getParameters() - Method in class com.hazelcast.collection.impl.list.client.ListSetRequest
-  
- getParameters() - Method in class com.hazelcast.collection.impl.list.client.ListSubRequest
-  
- getParameters() - Method in class com.hazelcast.collection.impl.queue.client.AddAllRequest
-  
- getParameters() - Method in class com.hazelcast.collection.impl.queue.client.AddListenerRequest
-  
- getParameters() - Method in class com.hazelcast.collection.impl.queue.client.CompareAndRemoveRequest
-  
- getParameters() - Method in class com.hazelcast.collection.impl.queue.client.ContainsRequest
-  
- getParameters() - Method in class com.hazelcast.collection.impl.queue.client.DrainRequest
-  
- getParameters() - Method in class com.hazelcast.collection.impl.queue.client.OfferRequest
-  
- getParameters() - Method in class com.hazelcast.collection.impl.queue.client.PollRequest
-  
- getParameters() - Method in class com.hazelcast.collection.impl.queue.client.RemoveRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.atomiclong.client.AddAndGetRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.atomiclong.client.ApplyRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.atomiclong.client.CompareAndSetRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.atomiclong.client.GetAndAddRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.atomicreference.client.AbstractAlterRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.atomicreference.client.ApplyRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.atomicreference.client.CompareAndSetRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.atomicreference.client.ContainsRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.atomicreference.client.GetAndSetRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.atomicreference.client.SetRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.lock.client.AwaitRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.lock.client.IsLockedRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.lock.client.LockRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.lock.client.UnlockRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.semaphore.client.AcquireRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.semaphore.client.AvailableRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.semaphore.client.DrainRequest
-  
- getParameters() - Method in class com.hazelcast.concurrent.semaphore.client.SemaphoreRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapAddEntryListenerRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapAddIndexRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapAddPartitionLostListenerRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapContainsKeyRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapContainsValueRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapDeleteRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapEvictRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapGetAllRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapGetRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapPutAllRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapPutIfAbsentRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapPutRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapPutTransientRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapQueryRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapReplaceIfSameRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapReplaceRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapSetRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapTryPutRequest
-  
- getParameters() - Method in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-  
- getParameters() - Method in class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-  
- getParameters() - Method in class com.hazelcast.multimap.impl.client.ContainsRequest
-  
- getParameters() - Method in class com.hazelcast.multimap.impl.client.CountRequest
-  
- getParameters() - Method in class com.hazelcast.multimap.impl.client.GetAllRequest
-  
- getParameters() - Method in class com.hazelcast.multimap.impl.client.KeyBasedContainsRequest
-  
- getParameters() - Method in class com.hazelcast.multimap.impl.client.PutRequest
-  
- getParameters() - Method in class com.hazelcast.multimap.impl.client.RemoveAllRequest
-  
- getParameters() - Method in class com.hazelcast.multimap.impl.client.RemoveRequest
-  
- getParameters() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
-  
- getParameters() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsKeyRequest
-  
- getParameters() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsValueRequest
-  
- getParameters() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapGetRequest
-  
- getParameters() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-  
- getParameters() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutTtlRequest
-  
- getParameters() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveRequest
-  
- getParameters() - Method in class com.hazelcast.ringbuffer.impl.client.AddAllRequest
-  
- getParameters() - Method in class com.hazelcast.ringbuffer.impl.client.AddRequest
-  
- getParameters() - Method in class com.hazelcast.ringbuffer.impl.client.CapacityRequest
-  
- getParameters() - Method in class com.hazelcast.ringbuffer.impl.client.HeadSequenceRequest
-  
- getParameters() - Method in class com.hazelcast.ringbuffer.impl.client.ReadManyRequest
-  
- getParameters() - Method in class com.hazelcast.ringbuffer.impl.client.ReadOneRequest
-  
- getParameters() - Method in class com.hazelcast.ringbuffer.impl.client.RemainingCapacityRequest
-  
- getParameters() - Method in class com.hazelcast.ringbuffer.impl.client.SizeRequest
-  
- getParameters() - Method in class com.hazelcast.ringbuffer.impl.client.TailSequenceRequest
-  
- getParameters() - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-  
- getParameters() - Method in class com.hazelcast.topic.impl.client.PublishRequest
-  
- getParent() - Method in enum com.hazelcast.client.config.ClientProperty
-  
- getParent() - Method in enum com.hazelcast.instance.GroupProperty
-  
- getParent() - Method in interface com.hazelcast.instance.HazelcastProperty
- 
- getPartition() - Method in class com.hazelcast.cache.impl.client.CacheIterateRequest
-  
- getPartition() - Method in class com.hazelcast.cache.impl.client.CachePutAllRequest
-  
- getPartition() - Method in class com.hazelcast.client.impl.client.KeyBasedClientRequest
-  
- getPartition() - Method in class com.hazelcast.client.impl.client.PartitionClientRequest
-  
- getPartition(Object) - Method in class com.hazelcast.client.proxy.PartitionServiceProxy
-  
- getPartition(int) - Method in interface com.hazelcast.client.spi.ClientPartitionService
-  
- getPartition(int) - Method in class com.hazelcast.client.spi.impl.ClientPartitionServiceImpl
-  
- getPartition() - Method in class com.hazelcast.collection.impl.collection.client.CollectionRequest
-  
- getPartition() - Method in class com.hazelcast.collection.impl.queue.client.QueueRequest
-  
- getPartition() - Method in class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
-  
- getPartition() - Method in class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
-  
- getPartition() - Method in class com.hazelcast.concurrent.atomiclong.client.ReadRequest
-  
- getPartition() - Method in class com.hazelcast.concurrent.atomicreference.client.AbstractAlterRequest
-  
- getPartition() - Method in class com.hazelcast.concurrent.atomicreference.client.ModifyRequest
-  
- getPartition() - Method in class com.hazelcast.concurrent.atomicreference.client.ReadRequest
-  
- getPartition() - Method in class com.hazelcast.concurrent.semaphore.client.SemaphoreRequest
-  
- getPartition(Object) - Method in interface com.hazelcast.core.PartitionService
- 
Returns the partition that the given key belongs to. 
- getPartition() - Method in class com.hazelcast.map.impl.client.MapGetAllRequest
-  
- getPartition() - Method in class com.hazelcast.map.impl.client.MapKeyBasedClientRequest
-  
- getPartition() - Method in class com.hazelcast.map.impl.client.MapPutAllRequest
-  
- getPartition() - Method in class com.hazelcast.multimap.impl.client.MultiMapKeyBasedRequest
-  
- getPartition(int) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getPartition(int, boolean) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getPartition(int) - Method in interface com.hazelcast.partition.InternalPartitionService
- 
Returns the InternalPartition for a given partitionId. 
- getPartition(int, boolean) - Method in interface com.hazelcast.partition.InternalPartitionService
- 
Returns the InternalPartition for a given partitionId. 
- getPartition(Object) - Method in class com.hazelcast.partition.PartitionServiceProxy
-  
- getPartition(int) - Method in class com.hazelcast.partition.PartitionServiceProxy
-  
- getPartition() - Method in class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-  
- getPartition() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsKeyRequest
-  
- getPartition() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapGetRequest
-  
- getPartition() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutTtlRequest
-  
- getPartition() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveRequest
-  
- getPartition() - Method in class com.hazelcast.ringbuffer.impl.client.RingbufferRequest
-  
- getPartition() - Method in class com.hazelcast.topic.impl.client.PublishRequest
-  
- getPartition() - Method in class com.hazelcast.transaction.client.FinalizeXATransactionRequest
-  
- getPartitionContainer(int) - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- getPartitionContainer(int) - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- getPartitionContainer(int) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- getPartitionCount() - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-  
- getPartitionCount() - Method in interface com.hazelcast.client.spi.ClientPartitionService
-  
- getPartitionCount() - Method in class com.hazelcast.client.spi.impl.ClientPartitionServiceImpl
-  
- getPartitionCount() - Method in class com.hazelcast.internal.management.dto.PartitionServiceBeanDTO
-  
- getPartitionCount() - Method in class com.hazelcast.jmx.PartitionServiceMBean
-  
- getPartitionCount() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getPartitionCount() - Method in interface com.hazelcast.partition.InternalPartitionService
- 
Returns the number of partitions. 
- getPartitionGroupConfig() - Method in class com.hazelcast.config.Config
-  
- getPartitionHash() - Method in class com.hazelcast.internal.serialization.impl.HeapData
-  
- getPartitionHash() - Method in interface com.hazelcast.nio.serialization.Data
- 
Returns partition hash calculated for serialized object. 
- getPartitionId() - Method in class com.hazelcast.cache.impl.CachePartitionEventData
-  
- getPartitionId() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-  
- getPartitionId(NodeEngine, Data) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
-  
- getPartitionId() - Method in class com.hazelcast.cache.impl.event.CachePartitionLostEvent
- 
Returns the partition ID that has been lost for the given cache. 
- getPartitionId() - Method in class com.hazelcast.client.impl.ClientEngineImpl.ClientPacketProcessor
-  
- getPartitionId() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
- 
Returns the partition id field. 
- getPartitionId() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-  
- getPartitionId() - Method in class com.hazelcast.client.impl.protocol.task.NoSuchMessageTask
-  
- getPartitionId(Data) - Method in interface com.hazelcast.client.spi.ClientPartitionService
-  
- getPartitionId(Object) - Method in interface com.hazelcast.client.spi.ClientPartitionService
-  
- getPartitionId() - Method in class com.hazelcast.client.spi.impl.ClientInvocation
-  
- getPartitionId(Data) - Method in class com.hazelcast.client.spi.impl.ClientPartitionServiceImpl
-  
- getPartitionId(Object) - Method in class com.hazelcast.client.spi.impl.ClientPartitionServiceImpl
-  
- getPartitionId() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- getPartitionId() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- getPartitionId() - Method in class com.hazelcast.concurrent.lock.LockProxy
-  
- getPartitionId() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-  
- getPartitionId() - Method in class com.hazelcast.core.MigrationEvent
- 
Returns the id of the partition which is (or is being) migrated 
- getPartitionId() - Method in interface com.hazelcast.core.Partition
- 
Returns the id of the partition. 
- getPartitionId() - Method in class com.hazelcast.map.impl.event.MapPartitionEventData
-  
- getPartitionId() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntry
-  
- getPartitionId() - Method in class com.hazelcast.map.impl.operation.MapPartitionDestroyTask
-  
- getPartitionId() - Method in class com.hazelcast.map.impl.PartitionContainer
-  
- getPartitionId() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- getPartitionId() - Method in interface com.hazelcast.map.impl.querycache.event.sequence.Sequenced
- 
Returns partition id which this sequence belongs to. 
- getPartitionId() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- getPartitionId() - Method in class com.hazelcast.map.MapPartitionLostEvent
- 
Returns the partition id that has been lost for the given map 
- getPartitionId() - Method in class com.hazelcast.mapreduce.impl.notification.IntermediateChunkNotification
-  
- getPartitionId() - Method in class com.hazelcast.mapreduce.impl.notification.LastChunkNotification
-  
- getPartitionId() - Method in class com.hazelcast.mapreduce.impl.notification.ReducingFinishedNotification
-  
- getPartitionId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionResult
-  
- getPartitionId() - Method in class com.hazelcast.nio.Packet
- 
Returns the partition id of this packet. 
- getPartitionId(Data) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getPartitionId(Object) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getPartitionId() - Method in class com.hazelcast.partition.impl.PartitionReplicaChangeEvent
-  
- getPartitionId() - Method in interface com.hazelcast.partition.InternalPartition
- 
Returns the partition id. 
- getPartitionId() - Method in class com.hazelcast.partition.InternalPartitionLostEvent
- 
The partition id that is lost 
- getPartitionId(Data) - Method in interface com.hazelcast.partition.InternalPartitionService
- 
Returns the partition id for a Data key. 
- getPartitionId(Object) - Method in interface com.hazelcast.partition.InternalPartitionService
- 
Returns the partition id for a given object. 
- getPartitionId() - Method in class com.hazelcast.partition.MigrationInfo
-  
- getPartitionId() - Method in interface com.hazelcast.partition.PartitionEvent
- 
Partition id that the event is dispatch for 
- getPartitionId() - Method in class com.hazelcast.partition.PartitionInfo
-  
- getPartitionId() - Method in class com.hazelcast.partition.PartitionLostEvent
- 
Returns the lost partition id. 
- getPartitionId() - Method in class com.hazelcast.partition.PartitionServiceProxy.PartitionProxy
-  
- getPartitionId(Data) - Method in class com.hazelcast.spi.AbstractDistributedObject
-  
- getPartitionId() - Method in class com.hazelcast.spi.impl.operationexecutor.OperationRunner
- 
Returns the partitionId this OperationRunner is responsible for. 
- getPartitionId() - Method in interface com.hazelcast.spi.impl.PartitionSpecificRunnable
- 
Returns the partition-id. 
- getPartitionId() - Method in class com.hazelcast.spi.impl.PortableCachePartitionLostEvent
-  
- getPartitionId() - Method in class com.hazelcast.spi.impl.PortableMapPartitionLostEvent
-  
- getPartitionId() - Method in class com.hazelcast.spi.impl.PortablePartitionLostEvent
-  
- getPartitionId() - Method in class com.hazelcast.spi.InvocationBuilder
- 
Returns the partition id. 
- getPartitionId() - Method in class com.hazelcast.spi.Operation
- 
Returns the id of the partition that this Operation will be executed upon. 
- getPartitionId() - Method in interface com.hazelcast.spi.PartitionAwareOperation
- 
Gets the partition id. 
- getPartitionId() - Method in class com.hazelcast.spi.PartitionMigrationEvent
- 
Gets the partition id. 
- getPartitionId() - Method in class com.hazelcast.spi.PartitionReplicationEvent
- 
Gets the id of the partition. 
- getPartitionIds() - Method in class com.hazelcast.map.impl.query.QueryResult
-  
- getPartitioningStrategy(ClassLoader) - Method in class com.hazelcast.client.impl.DefaultClientExtension
-  
- getPartitioningStrategy() - Method in class com.hazelcast.config.PartitioningStrategyConfig
-  
- getPartitioningStrategy(ClassLoader) - Method in class com.hazelcast.instance.DefaultNodeExtension
-  
- getPartitioningStrategy() - Method in class com.hazelcast.map.impl.MapContainer
-  
- getPartitioningStrategy(NodeEngine, String, PartitioningStrategyConfig) - Static method in class com.hazelcast.map.impl.PartitioningStrategyFactory
- 
- getPartitioningStrategyClass() - Method in class com.hazelcast.config.PartitioningStrategyConfig
-  
- getPartitioningStrategyConfig() - Method in class com.hazelcast.config.MapConfig
-  
- getPartitioningStrategyConfig() - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- getPartitionKey() - Method in class com.hazelcast.client.spi.ClientProxy
-  
- getPartitionKey() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorImpl
-  
- getPartitionKey() - Method in interface com.hazelcast.core.DistributedObject
- 
Returns the key of the partition that this DistributedObject is assigned to. 
- getPartitionKey() - Method in interface com.hazelcast.core.PartitionAware
- 
The key that will be used by Hazelcast to specify the partition. 
- getPartitionKey() - Method in class com.hazelcast.core.PartitionAwareKey
-  
- getPartitionKey(K) - Method in interface com.hazelcast.core.PartitioningStrategy
- 
Returns the key object that will be used by Hazelcast to specify the partition. 
- getPartitionKey() - Method in class com.hazelcast.executor.impl.RunnableAdapter
-  
- getPartitionKey() - Method in class com.hazelcast.jmx.AtomicLongMBean
-  
- getPartitionKey() - Method in class com.hazelcast.jmx.AtomicReferenceMBean
-  
- getPartitionKey() - Method in class com.hazelcast.jmx.CountDownLatchMBean
-  
- getPartitionKey() - Method in class com.hazelcast.jmx.LockMBean
-  
- getPartitionKey() - Method in class com.hazelcast.jmx.QueueMBean
-  
- getPartitionKey() - Method in class com.hazelcast.jmx.SemaphoreMBean
-  
- getPartitionKey() - Method in class com.hazelcast.jmx.SetMBean
-  
- getPartitionKey() - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-  
- getPartitionKey(Object) - Method in class com.hazelcast.partition.strategy.DefaultPartitioningStrategy
-  
- getPartitionKey(Object) - Method in class com.hazelcast.partition.strategy.StringAndPartitionAwarePartitioningStrategy
-  
- getPartitionKey(Object) - Method in class com.hazelcast.partition.strategy.StringPartitioningStrategy
-  
- getPartitionKey(String) - Static method in class com.hazelcast.partition.strategy.StringPartitioningStrategy
-  
- getPartitionKey() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-  
- getPartitionKey() - Method in class com.hazelcast.spi.AbstractDistributedObject
-  
- getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.CacheConfig
- 
Gets the partition lost listener references added to cache configuration. 
- getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Gets the partition lost listener references added to cache configuration. 
- getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.MapConfig
-  
- getPartitionLostListenerConfigs() - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- getPartitionMigrationTimeout() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getPartitionOperationRunners() - Method in class com.hazelcast.spi.impl.operationexecutor.classic.ClassicOperationExecutor
-  
- getPartitionOperationRunners() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
- 
Gets all the operation handlers for the partitions. 
- getPartitionOperationThreadCount() - Method in class com.hazelcast.spi.impl.operationexecutor.classic.ClassicOperationExecutor
-  
- getPartitionOperationThreadCount() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
- 
Deprecated. 
- getPartitionOperationThreadCount() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- getPartitionOperationThreadCount() - Method in interface com.hazelcast.spi.OperationService
- 
Deprecated. 
- getPartitionOwner(int) - Method in interface com.hazelcast.client.spi.ClientPartitionService
-  
- getPartitionOwner(int) - Method in class com.hazelcast.client.spi.impl.ClientPartitionServiceImpl
-  
- getPartitionOwner(int) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getPartitionOwner(int) - Method in interface com.hazelcast.partition.InternalPartitionService
- 
Gets the owner of the partition if it's set. 
- getPartitionOwnerOrWait(int) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getPartitionOwnerOrWait(int) - Method in interface com.hazelcast.partition.InternalPartitionService
- 
Gets the owner of the partition. 
- getPartitionReplicaVersions(int) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getPartitionReplicaVersions(int) - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- getPartitions() - Method in class com.hazelcast.client.impl.client.MultiPartitionClientRequest
-  
- getPartitions() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMultiPartitionMessageTask
-  
- getPartitions() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeysMessageTask
-  
- getPartitions() - Method in class com.hazelcast.client.proxy.PartitionServiceProxy
-  
- getPartitions() - Method in interface com.hazelcast.core.PartitionService
- 
Returns a set containing all the  Partitions in the cluster. 
- getPartitions() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-  
- getPartitions() - Method in class com.hazelcast.monitor.impl.MemberPartitionStateImpl
-  
- getPartitions() - Method in interface com.hazelcast.monitor.MemberPartitionState
- 
Get list of owned partitions of the member 
- getPartitions() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getPartitions() - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- getPartitions() - Method in class com.hazelcast.partition.PartitionRuntimeState
-  
- getPartitions() - Method in class com.hazelcast.partition.PartitionServiceProxy
-  
- getPartitionService() - Method in interface com.hazelcast.client.ClientEngine
-  
- getPartitionService() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- getPartitionService() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getPartitionService() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getPartitionService() - Method in class com.hazelcast.client.spi.ClientContext
-  
- getPartitionService() - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the partition service of this Hazelcast instance. 
- getPartitionService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getPartitionService() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getPartitionService() - Method in class com.hazelcast.instance.Node
-  
- getPartitionService() - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getPartitionService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getPartitionService() - Method in interface com.hazelcast.spi.NodeEngine
- 
Gets the InternalPartitionService. 
- getPartitionServiceBean() - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
-  
- getPartitionServiceMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getPartitionServiceProxy() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getPartitionServiceProxy() - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- GetPartitionsMessageTask - Class in com.hazelcast.client.impl.protocol.task
-  
- GetPartitionsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
-  
- GetPartitionsRequest - Class in com.hazelcast.partition.client
-  
- GetPartitionsRequest() - Constructor for class com.hazelcast.partition.client.GetPartitionsRequest
-  
- getPartitionStates() - Method in class com.hazelcast.mapreduce.impl.task.JobProcessInformationImpl
-  
- getPartitionStates() - Method in class com.hazelcast.mapreduce.impl.task.TransferableJobProcessInformation
-  
- getPartitionStates() - Method in interface com.hazelcast.mapreduce.JobProcessInformation
- 
- getPartitionStateVersion() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getPartitionStateVersion() - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- getPassword() - Method in class com.hazelcast.config.GroupConfig
- 
Gets the password of the group. 
- getPassword() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-  
- getPassword() - Method in class com.hazelcast.security.UsernamePasswordCredentials
- 
Gets the password. 
- getPayload() - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicMessage
-  
- getPendingPacketCount() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- getPendingTaskCount() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-  
- getPendingTaskCount() - Method in interface com.hazelcast.monitor.LocalExecutorStats
- 
Returns the number of pending operations on the executor service. 
- getPermission(String, String, String...) - Static method in class com.hazelcast.security.permission.ActionConstants
- 
Creates a permission 
- getPermissions(Subject, Class<? extends Permission>) - Method in interface com.hazelcast.security.IPermissionPolicy
- 
Determines permissions of subject. 
- getPermissions() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
-  
- getPollOperationCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- getPollOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
- 
Returns the number of poll/take/remove operations. 
- getPollWaitNotifyKey() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- getPoolSize() - Method in class com.hazelcast.config.ExecutorConfig
- 
Gets the number of executor threads per member for the executor. 
- getPoolSize() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-  
- getPoolSize() - Method in interface com.hazelcast.util.executor.ManagedExecutorService
-  
- getPort() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- getPort() - Method in class com.hazelcast.config.NetworkConfig
- 
Returns the port the Hazelcast member will try to bind on. 
- getPort() - Method in class com.hazelcast.instance.AbstractMember
-  
- getPort() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getPort() - Method in class com.hazelcast.nio.Address
-  
- getPort() - Method in interface com.hazelcast.nio.Connection
- 
The remote port. 
- getPort() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- getPort() - Method in class com.hazelcast.util.AddressUtil.AddressHolder
-  
- getPortableContext() - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1
-  
- getPortableContext() - Method in interface com.hazelcast.internal.serialization.SerializationService
-  
- getPortableFactories() - Method in class com.hazelcast.config.SerializationConfig
-  
- getPortableFactoryClasses() - Method in class com.hazelcast.config.SerializationConfig
-  
- getPortableVersion() - Method in class com.hazelcast.config.SerializationConfig
- 
Portable version will be used to differentiate two versions of the same class that have changes on the class,
 like adding/removing a field or changing a type of a field. 
- getPortableVersion(Portable, int) - Static method in class com.hazelcast.internal.serialization.impl.SerializationUtil
-  
- getPortCount() - Method in class com.hazelcast.config.NetworkConfig
- 
Returns the maximum number of ports allowed to try to bind on. 
- getPossibleAddresses() - Method in class com.hazelcast.cluster.impl.DiscoveryJoiner
-  
- getPossibleAddresses() - Method in class com.hazelcast.cluster.impl.TcpIpJoiner
-  
- getPossibleInetAddressesFor(Inet6Address) - Static method in class com.hazelcast.util.AddressUtil
-  
- getPossibleSocketAddresses(int, String, int) - Static method in class com.hazelcast.client.util.AddressHelper
-  
- getPostJoinOperation() - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- getPostJoinOperation() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- getPostJoinOperation() - Method in class com.hazelcast.map.impl.MapService
-  
- getPostJoinOperation() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-  
- getPostJoinOperation() - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-  
- getPostJoinOperation() - Method in interface com.hazelcast.spi.PostJoinAwareService
- 
Post join operations must be lock free, meaning no locks at all:
 no partition locks, no key-based locks, no service level locks,
 no database interaction! 
- getPostJoinOperations() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
- 
Post join operations must be lock free; means no locks at all;
 no partition locks, no key-based locks, no service level locks!
  
 Post join operations should return response, at least a null response. 
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapQueryMessageTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPagingPredicateMessageTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPredicateMessageTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntrySetMessageTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPagingPredicateMessageTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesMessageTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPagingPredicateMessageTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPredicateMessageTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.AbstractMapReduceTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForCustomMessageTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForListMessageTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMapMessageTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMultiMapMessageTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForSetMessageTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerMessageTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyMessageTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerWithPredicateMessageTask
-  
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddNearCacheListenerMessageTask
-  
- getPredicate() - Method in class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-  
- getPredicate() - Method in class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-  
- getPredicate() - Method in class com.hazelcast.map.impl.client.MapAddEntryListenerRequest
-  
- getPredicate() - Method in class com.hazelcast.map.impl.client.MapAddEntryListenerSqlRequest
-  
- getPredicate() - Method in class com.hazelcast.map.impl.client.MapQueryRequest
-  
- getPredicate() - Method in class com.hazelcast.map.impl.client.MapSQLQueryRequest
-  
- getPredicate() - Method in class com.hazelcast.map.impl.client.TxnMapRequest
-  
- getPredicate() - Method in class com.hazelcast.map.impl.client.TxnMapRequestWithSQLQuery
-  
- getPredicate() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryBackupOperation
-  
- getPredicate() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-  
- getPredicate() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateBackupOperation
-  
- getPredicate() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperation
-  
- getPredicate() - Method in class com.hazelcast.map.impl.query.QueryEventFilter
-  
- getPredicate() - Method in class com.hazelcast.query.PagingPredicate
-  
- getPredicate() - Method in class com.hazelcast.query.SqlPredicate
-  
- getPredicateConfig() - Method in class com.hazelcast.config.QueryCacheConfig
- 
Returns the predicate of QueryCache.
 
- getPreparedXids() - Method in class com.hazelcast.transaction.impl.xa.XAService
-  
- getPrincipal() - Method in interface com.hazelcast.client.ClientEndpoint
-  
- getPrincipal() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- getPrincipal() - Method in class com.hazelcast.client.spi.impl.ClusterListenerSupport
-  
- getPrincipal() - Method in class com.hazelcast.config.PermissionConfig
-  
- getPrincipal() - Method in class com.hazelcast.security.AbstractCredentials
-  
- getPrincipal() - Method in interface com.hazelcast.security.Credentials
- 
Returns principal of endpoint. 
- getPriorityFramesReadCounter() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingSocketReader
-  
- getPriorityFramesReadCounter() - Method in interface com.hazelcast.nio.tcp.SocketReader
- 
Gets the Counter that counts the number of priority packets that have been read. 
- getPriorityFramesReadCounter() - Method in class com.hazelcast.nio.tcp.spinning.SpinningSocketReader
-  
- getPriorityOperationExecutorQueueSize() - Method in class com.hazelcast.spi.impl.operationexecutor.classic.ClassicOperationExecutor
-  
- getPriorityOperationExecutorQueueSize() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
- 
Deprecated. 
- getPriorityOperationExecutorQueueSize() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- getPriorityOperationExecutorQueueSize() - Method in interface com.hazelcast.spi.OperationService
- 
Deprecated. 
- getPrivateAddress() - Method in class com.hazelcast.spi.discovery.DiscoveryNode
- 
Returns the private address of the discovered node. 
- getPrivateAddress() - Method in class com.hazelcast.spi.discovery.SimpleDiscoveryNode
-  
- getPrivateIpAddresses() - Method in class com.hazelcast.aws.AWSClient
-  
- getProbeInstance(String) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
-  
- getProcessedRecords() - Method in class com.hazelcast.mapreduce.impl.task.JobProcessInformationImpl
-  
- getProcessedRecords() - Method in class com.hazelcast.mapreduce.impl.task.TransferableJobProcessInformation
-  
- getProcessedRecords() - Method in interface com.hazelcast.mapreduce.JobProcessInformation
- 
Returns the number of processed records.
 The number of processed records is not a real time value, it is updated
 on a regular basis (after 1000 processed elements per node).
 
- getProgram(String...) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
-  
- getProperties() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- getProperties() - Method in class com.hazelcast.client.config.ClientConfig
- 
- getProperties() - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
-  
- getProperties() - Method in class com.hazelcast.config.AbstractConfigBuilder
-  
- getProperties() - Method in class com.hazelcast.config.Config
-  
- getProperties() - Method in class com.hazelcast.config.CredentialsFactoryConfig
-  
- getProperties() - Method in class com.hazelcast.config.DiscoveryStrategyConfig
-  
- getProperties() - Method in class com.hazelcast.config.LoginModuleConfig
-  
- getProperties() - Method in class com.hazelcast.config.MapStoreConfig
- 
Returns all the properties 
- getProperties() - Method in class com.hazelcast.config.PermissionPolicyConfig
-  
- getProperties() - Method in class com.hazelcast.config.QueueStoreConfig
-  
- getProperties() - Method in class com.hazelcast.config.ServiceConfig
-  
- getProperties() - Method in class com.hazelcast.config.SocketInterceptorConfig
- 
Gets all properties. 
- getProperties() - Method in class com.hazelcast.config.SSLConfig
- 
Gets all properties. 
- getProperties() - Method in class com.hazelcast.config.XmlConfigBuilder
- 
Gets the current used properties. 
- getProperties() - Method in class com.hazelcast.jclouds.ComputeServiceBuilder
-  
- getProperties() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
- 
Returns an immutable copy of the configuration properties. 
- getProperties() - Method in class com.hazelcast.spi.discovery.DiscoveryNode
- 
Returns a set of unmodifiable properties that are assigned to the discovered node. 
- getProperties() - Method in class com.hazelcast.spi.discovery.SimpleDiscoveryNode
-  
- getProperties() - Method in class com.hazelcast.web.WebFilter
-  
- getProperty(String) - Method in class com.hazelcast.client.config.ClientConfig
- 
Gets a named property already set or from system properties if not exists. 
- getProperty(HazelcastProperty) - Method in class com.hazelcast.client.config.ClientConfig
- 
- getProperty(String) - Method in class com.hazelcast.config.Config
- 
Gets a named property already set or from system properties if not exists. 
- getProperty(HazelcastProperty) - Method in class com.hazelcast.config.Config
- 
- getProperty(String) - Method in class com.hazelcast.config.MapStoreConfig
- 
Returns the given property 
- getProperty(String) - Method in class com.hazelcast.config.QueueStoreConfig
-  
- getProperty(String) - Method in class com.hazelcast.config.SocketInterceptorConfig
- 
Gets a property. 
- getProperty(String) - Method in class com.hazelcast.config.SSLConfig
- 
Gets a property. 
- getProtocolVersion() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getProxyCount() - Method in class com.hazelcast.jmx.ProxyServiceMBean
-  
- getProxyCount() - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyRegistry
- 
Returns the number of proxies for this ProxyRegistry. 
- getProxyCount() - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-  
- getProxyCount() - Method in interface com.hazelcast.spi.ProxyService
-  
- getProxyFactoryConfigs() - Method in class com.hazelcast.client.config.ClientConfig
- 
- getProxyInfos(Collection<ProxyInfo>) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyRegistry
- 
Gets the ProxyInfo of all proxies in this registry. 
- getProxyManager() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getProxyService() - Method in interface com.hazelcast.client.ClientEngine
-  
- getProxyService() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- getProxyService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getProxyService() - Method in interface com.hazelcast.spi.NodeEngine
- 
Gets the ProxyService. 
- getProxyServiceBean() - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
-  
- getProxyServiceMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getPublicAddress() - Method in class com.hazelcast.config.NetworkConfig
-  
- getPublicAddress() - Method in interface com.hazelcast.instance.AddressPicker
- 
Returns a public address to be advertised to other cluster members and clients. 
- getPublicAddress() - Method in class com.hazelcast.spi.discovery.DiscoveryNode
- 
Returns the public address of the discovered node if available. 
- getPublicAddress() - Method in class com.hazelcast.spi.discovery.SimpleDiscoveryNode
-  
- getPublisherAddress() - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicMessage
-  
- getPublisherName() - Method in class com.hazelcast.internal.management.request.ChangeWanStateRequest
-  
- getPublishingMember() - Method in class com.hazelcast.core.Message
- 
Returns the member that published the message. 
- getPublishOperationCount() - Method in class com.hazelcast.monitor.impl.LocalTopicStatsImpl
-  
- getPublishOperationCount() - Method in interface com.hazelcast.monitor.LocalTopicStats
- 
Returns the total number of published messages of this topic on this member 
- getPublishTime() - Method in class com.hazelcast.core.Message
- 
Return the time when the message is published 
- getPublishTime() - Method in class com.hazelcast.topic.impl.client.PortableMessage
-  
- getPublishTime() - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicMessage
-  
- getPutOperationCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getPutOperationCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getPutOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns the number of put operations 
- getQueryCacheConfigs() - Method in class com.hazelcast.client.config.ClientConfig
-  
- getQueryCacheConfigs() - Method in class com.hazelcast.config.MapConfig
- 
Returns all QueryCacheConfiginstances defined on thisMapConfig
 
- getQueryCacheConfigs() - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- getQueryExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getQueue() - Method in class com.hazelcast.client.console.ClientConsoleApp
-  
- getQueue(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getQueue(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getQueue(String) - Method in class com.hazelcast.client.proxy.txn.TransactionContextProxy
-  
- getQueue(String) - Method in class com.hazelcast.client.proxy.txn.xa.XATransactionContextProxy
-  
- getQueue(String) - Method in class com.hazelcast.client.txn.proxy.xa.XATransactionContextProxy
-  
- getQueue(String) - Method in class com.hazelcast.client.txn.TransactionContextProxy
-  
- getQueue() - Method in class com.hazelcast.console.ConsoleApp
-  
- getQueue(String) - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the distributed queue instance with the specified name. 
- getQueue(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getQueue(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getQueue(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getQueue(String) - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
-  
- getQueue(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
- 
Returns the transactional queue instance with the specified name. 
- getQueueCapacity() - Method in class com.hazelcast.config.ExecutorConfig
- 
Gets the queue capacity of the executor task. 
- getQueueCapacity() - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- getQueueConfig(String) - Method in class com.hazelcast.config.Config
-  
- getQueueConfigs() - Method in class com.hazelcast.config.Config
-  
- getQueueFullBehavior() - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- getQueueService() - Method in class com.hazelcast.collection.impl.queue.operations.QueueOperation
-  
- getQueueSize() - Method in class com.hazelcast.config.JobTrackerConfig
- 
Gets the maximum size of the queue; the maximum number of tasks that can wait to be processed. 
- getQueueSize() - Method in class com.hazelcast.spi.impl.operationservice.impl.AsyncResponsePacketHandler
-  
- getQueueSize() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-  
- getQueueSize() - Method in interface com.hazelcast.util.executor.ManagedExecutorService
-  
- getQueueSize() - Method in class com.hazelcast.util.executor.NamedThreadPoolExecutor
-  
- getQueueStoreConfig() - Method in class com.hazelcast.config.QueueConfig
- 
Get the QueueStore (load and store queue items from/to a database) configuration. 
- getQueueStoreConfig() - Method in class com.hazelcast.config.QueueConfigReadOnly
-  
- getQuorum(String) - Method in class com.hazelcast.quorum.impl.QuorumServiceImpl
-  
- getQuorum(String) - Method in interface com.hazelcast.quorum.QuorumService
- 
Returns the  Quorum instance for a given quorum name. 
- getQuorumConfig(String) - Method in class com.hazelcast.config.Config
-  
- getQuorumConfigs() - Method in class com.hazelcast.config.Config
-  
- getQuorumFunctionClassName() - Method in class com.hazelcast.config.QuorumConfig
-  
- getQuorumFunctionImplementation() - Method in class com.hazelcast.config.QuorumConfig
-  
- getQuorumName(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
- 
Gets the name of the quorum associated with specified cache 
- getQuorumName() - Method in class com.hazelcast.config.CacheConfig
- 
Gets the name of the associated quorum if any. 
- getQuorumName() - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- getQuorumName() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Gets the name of the associated quorum if any. 
- getQuorumName() - Method in class com.hazelcast.config.MapConfig
-  
- getQuorumName() - Method in class com.hazelcast.map.impl.MapContainer
-  
- getQuorumName(String) - Method in class com.hazelcast.map.impl.MapQuorumAwareService
-  
- getQuorumName(String) - Method in class com.hazelcast.map.impl.MapService
-  
- getQuorumName(String) - Method in interface com.hazelcast.spi.QuorumAwareService
-  
- getQuorumService() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getQuorumService() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getQuorumService() - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the quorum service of this Hazelcast instance. 
- getQuorumService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getQuorumService() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getQuorumService() - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getQuorumService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getQuorumService() - Method in interface com.hazelcast.spi.NodeEngine
- 
Gets the QuorumService. 
- getRandomSamples(int) - Method in class com.hazelcast.util.SampleableConcurrentHashMap
- 
Gets and returns samples as sampleCount.
 
- getRatio() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-  
- getRatio() - Method in interface com.hazelcast.monitor.NearCacheStats
- 
Returns the hit/miss ratio of the locally owned entries. 
- getRawDataInput() - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- getRawDataInput() - Method in interface com.hazelcast.nio.serialization.PortableReader
- 
- getRawDataOutput() - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
-  
- getRawDataOutput() - Method in interface com.hazelcast.nio.serialization.PortableWriter
- 
After writing portable fields, one can write remaining fields in old fashioned way consecutively at the end
 of stream. 
- getReadBatchSize() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
- 
Gets the maximum number of items to read in a batch. 
- getReadBatchSize() - Method in class com.hazelcast.config.ReliableTopicConfig
- 
Gets the maximum number of items to read in a batch. 
- getReadHandler() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- getReadHandler() - Method in class com.hazelcast.internal.ascii.AbstractTextCommand
-  
- getReadHandler() - Method in interface com.hazelcast.internal.ascii.TextCommand
-  
- getReadOnlyRecords() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- getReadOnlyRecords() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Returns a readonly map of the internal key value store. 
- getReason() - Method in class com.hazelcast.partition.impl.PartitionReplicaChangeEvent
-  
- getReceiveOperationCount() - Method in class com.hazelcast.monitor.impl.LocalTopicStatsImpl
-  
- getReceiveOperationCount() - Method in interface com.hazelcast.monitor.LocalTopicStats
- 
Returns the total number of received messages of this topic on this member 
- getRecord(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- getRecord(Data) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Gets internal record of the store by key. 
- getRecord(K) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- getRecord(K) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.BaseHeapNearCacheRecordStore
-  
- getRecord(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- getRecord(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- getRecordCollection(NodeEngine) - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
-  
- getRecordFactory() - Method in class com.hazelcast.jca.ConnectionFactoryImpl
-  
- getRecordFactoryConstructor() - Method in class com.hazelcast.map.impl.MapContainer
-  
- getRecordId() - Method in class com.hazelcast.multimap.impl.MultiMapRecord
-  
- getRecordId() - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
-  
- getRecordId() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
-  
- getRecordIds() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
-  
- getRecordList() - Method in class com.hazelcast.transaction.impl.TransactionLog
-  
- getRecordMap(Comparable) - Method in interface com.hazelcast.query.impl.IndexStore
-  
- getRecordMap(Comparable) - Method in class com.hazelcast.query.impl.SortedIndexStore
-  
- getRecordMap(Comparable) - Method in class com.hazelcast.query.impl.UnsortedIndexStore
-  
- getRecordOrNull(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- getRecordOrNull(Data, long, boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- getRecordOrNull(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
- 
Returns live record or null if record is already expired. 
- getRecords(Comparable[]) - Method in interface com.hazelcast.query.impl.Index
-  
- getRecords(Comparable) - Method in interface com.hazelcast.query.impl.Index
-  
- getRecords(Comparable[]) - Method in class com.hazelcast.query.impl.IndexImpl
-  
- getRecords(Comparable) - Method in class com.hazelcast.query.impl.IndexImpl
-  
- getRecords(Comparable) - Method in interface com.hazelcast.query.impl.IndexStore
-  
- getRecords(Set<Comparable>) - Method in interface com.hazelcast.query.impl.IndexStore
-  
- getRecords(Comparable) - Method in class com.hazelcast.query.impl.SortedIndexStore
-  
- getRecords(Set<Comparable>) - Method in class com.hazelcast.query.impl.SortedIndexStore
-  
- getRecords(Comparable) - Method in class com.hazelcast.query.impl.UnsortedIndexStore
-  
- getRecords(Set<Comparable>) - Method in class com.hazelcast.query.impl.UnsortedIndexStore
-  
- getRecords() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-  
- getRecords() - Method in class com.hazelcast.transaction.impl.xa.XATransactionDTO
-  
- getRecordStorageMemoryCost(R) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- getRecordStorageMemoryCost(NearCacheDataRecord) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.NearCacheDataRecordStore
-  
- getRecordStorageMemoryCost(NearCacheObjectRecord) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.NearCacheObjectRecordStore
-  
- getRecordStore(String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- getRecordStore(String) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-  
- getRecordStore(String, int) - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- getRecordStore(int, String) - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- getRecordStore(String) - Method in class com.hazelcast.map.impl.PartitionContainer
-  
- getRecordStore(String) - Method in class com.hazelcast.replicatedmap.impl.PartitionContainer
-  
- getRecordStoreForHotRestart(String) - Method in class com.hazelcast.map.impl.PartitionContainer
-  
- getRecordStoreHeapCost(String, PartitionContainer) - Method in class com.hazelcast.map.impl.eviction.EvictionCheckerImpl
-  
- getRecordStoreOrNull(String, int) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
-  
- getRecordStoreSize(String, PartitionContainer) - Method in class com.hazelcast.map.impl.eviction.EvictionCheckerImpl
-  
- getRecordValue(R) - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-  
- getReducerAddressByKey(Object) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-  
- getReducerByKey(Object) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-  
- getReducerEventInterests(int) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-  
- getReducerFactory() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.AbstractMapReduceTask
-  
- getReducerFactory() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForCustomMessageTask
-  
- getReducerFactory() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForListMessageTask
-  
- getReducerFactory() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMapMessageTask
-  
- getReducerFactory() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMultiMapMessageTask
-  
- getReducerFactory() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForSetMessageTask
-  
- getReducerFactory() - Method in interface com.hazelcast.mapreduce.aggregation.Aggregation
- 
Returns the ReducerFactory for this aggregation. 
- getReducerFactory() - Method in interface com.hazelcast.mapreduce.aggregation.impl.AggType
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalAvgAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMaxAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMinAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalSumAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerAvgAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMaxAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMinAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerSumAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.ComparableMaxAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.ComparableMinAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.CountAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DistinctValuesAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleAvgAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleMaxAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleMinAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleSumAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerAvgAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerMaxAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerMinAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerSumAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongAvgAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongMaxAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongMinAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongSumAggregation
-  
- getReducerFactory() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-  
- getReducerTask(String) - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-  
- getReference() - Method in class com.hazelcast.jca.ConnectionFactoryImpl
-  
- getReferenceCallId() - Method in class com.hazelcast.concurrent.lock.operations.BaseLockOperation
-  
- getReferenceContainer(String) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-  
- getReferenceContainer() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
-  
- getRegion() - Method in class com.hazelcast.config.AwsConfig
- 
Gets the region where the EC2 instances running the Hazelcast members will be running. 
- getRegion() - Method in class com.hazelcast.hibernate.region.CollectionRegionAccessStrategyAdapter
-  
- getRegion() - Method in class com.hazelcast.hibernate.region.EntityRegionAccessStrategyAdapter
-  
- getRegion() - Method in class com.hazelcast.hibernate.region.NaturalIdRegionAccessStrategyAdapter
-  
- getRegionsSet() - Method in class com.hazelcast.jclouds.ComputeServiceBuilder
-  
- getRegistrationId() - Method in class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
-  
- getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.AbstractRemoveListenerMessageTask
-  
- getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
-  
- getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
-  
- getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
-  
- getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveListenerMessageTask
-  
- getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveEntryListenerMessageTask
-  
- getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemovePartitionLostListenerMessageTask
-  
- getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
-  
- getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveListenerMessageTask
-  
- getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
-  
- getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
-  
- getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
-  
- getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveListenerMessageTask
-  
- getRegistrationId() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicRemoveMessageListenerMessageTask
-  
- getRegistrationIdMap() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceSegment
-  
- getRegistrations(String) - Method in class com.hazelcast.map.impl.event.MapEventPublisherImpl
-  
- getRegistrations(String, String) - Method in interface com.hazelcast.spi.EventService
- 
Returns all registrations belonging to the given service and topic. 
- getRegistrations(String, String) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-  
- getRegistrations(String, boolean) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceSegment
-  
- getRegistrationsAsArray(String, String) - Method in interface com.hazelcast.spi.EventService
- 
Returns all registrations belonging to the given service and topic as an array. 
- getRegistrationsAsArray(String, String) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-  
- getRejectedOfferOperationCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- getRejectedOfferOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
- 
Returns the number of rejected offers. 
- getReleaseVersion() - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-  
- getReliableTopic(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getReliableTopic(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getReliableTopic(String) - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the reliable ReliableTopic instance with the specified name. 
- getReliableTopic(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getReliableTopic(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getReliableTopic(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getReliableTopicConfig(String) - Method in class com.hazelcast.client.config.ClientConfig
- 
Gets the ClientReliableTopicConfig for a given reliable topic name. 
- getReliableTopicConfig(String) - Method in class com.hazelcast.config.Config
-  
- getReliableTopicConfigs() - Method in class com.hazelcast.config.Config
-  
- GetRemainingLeaseRequest - Class in com.hazelcast.concurrent.lock.client
-  
- GetRemainingLeaseRequest() - Constructor for class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-  
- GetRemainingLeaseRequest(Data) - Constructor for class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-  
- getRemainingLeaseTime() - Method in class com.hazelcast.client.proxy.ClientLockProxy
-  
- getRemainingLeaseTime() - Method in class com.hazelcast.concurrent.lock.LockProxy
-  
- getRemainingLeaseTime(NodeEngine, Data) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
-  
- getRemainingLeaseTime() - Method in interface com.hazelcast.concurrent.lock.LockResource
-  
- getRemainingLeaseTime(Data) - Method in interface com.hazelcast.concurrent.lock.LockStore
-  
- getRemainingLeaseTime(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- getRemainingLeaseTime(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
-  
- getRemainingLeaseTime() - Method in interface com.hazelcast.core.ILock
- 
Returns remaining lease time in milliseconds. 
- getRemainingLeaseTime() - Method in class com.hazelcast.jmx.LockMBean
-  
- GetRemainingLeaseTimeOperation - Class in com.hazelcast.concurrent.lock.operations
-  
- GetRemainingLeaseTimeOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.GetRemainingLeaseTimeOperation
-  
- GetRemainingLeaseTimeOperation(ObjectNamespace, Data) - Constructor for class com.hazelcast.concurrent.lock.operations.GetRemainingLeaseTimeOperation
-  
- getRemainingQueueCapacity() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-  
- getRemainingQueueCapacity() - Method in interface com.hazelcast.util.executor.ManagedExecutorService
-  
- getRemainingQueueCapacity() - Method in class com.hazelcast.util.executor.NamedThreadPoolExecutor
-  
- getRemoteEndpoint() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- getRemoteOperationsCount() - Method in class com.hazelcast.jmx.OperationServiceMBean
-  
- getRemoteOperationsCount() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- getRemoteOperationsCount() - Method in interface com.hazelcast.spi.OperationService
- 
Deprecated. 
- getRemoteSocketAddress() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- getRemoteSocketAddress() - Method in interface com.hazelcast.nio.Connection
- 
Returns the address of the endpoint this Connection is connected to, or
 nullif it is unconnected.
 
- getRemoteSocketAddress() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- getRemoveOperationCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getRemoveOperationCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getRemoveOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns the number of Remove operations 
- getRemoveTime() - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
-  
- getReplicaAddress(int, InternalPartition, InternalPartitionService, int) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
- 
Gets replica address. 
- getReplicaAddress(int) - Method in interface com.hazelcast.partition.InternalPartition
- 
Returns Address of the replica. 
- getReplicaAddress(int) - Method in class com.hazelcast.partition.PartitionInfo
-  
- getReplicaAddresses() - Method in class com.hazelcast.partition.PartitionInfo
-  
- getReplicaCount() - Method in class com.hazelcast.partition.PartitionInfo
-  
- getReplicaIndex() - Method in class com.hazelcast.client.impl.client.PartitionClientRequest
-  
- getReplicaIndex() - Method in class com.hazelcast.partition.impl.PartitionReplicaChangeEvent
-  
- getReplicaIndex() - Method in class com.hazelcast.spi.InvocationBuilder
- 
Gets the replicaIndex. 
- getReplicaIndex() - Method in class com.hazelcast.spi.Operation
-  
- getReplicaIndex() - Method in class com.hazelcast.spi.PartitionReplicationEvent
- 
Gets the replica index. 
- getReplicatedMap(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getReplicatedMap(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getReplicatedMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the replicated map instance with the specified name. 
- getReplicatedMap(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getReplicatedMap(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getReplicatedMap(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getReplicatedMapConfig(String) - Method in class com.hazelcast.config.Config
-  
- getReplicatedMapConfig(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- getReplicatedMapConfigs() - Method in class com.hazelcast.config.Config
-  
- getReplicatedMapStats() - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-  
- getReplicatedMapStats() - Method in interface com.hazelcast.core.ReplicatedMap
- 
Returns LocalReplicatedMapStats for this replicated map. 
- getReplicatedMapStats() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-  
- getReplicatedRecord(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-  
- getReplicatedRecord(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- getReplicatedRecordStore(String, boolean, Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- getReplicatedRecordStore(String, boolean, int) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- getReplicationDelayMillis() - Method in class com.hazelcast.config.ReplicatedMapConfig
- 
Deprecated.
since new implementation will route puts to the partition owner nodes,
 caching won't help replication speed because most of the time subsequent puts will end up in different nodes. 
 
- getReplicationEventCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getReplicationEventCount() - Method in interface com.hazelcast.monitor.LocalReplicatedMapStats
- 
Deprecated.
replication is no more handled by event system. 
 
- getReplicationImpl() - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- getReplicationImplObject() - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- getReplicatorExecutorService() - Method in class com.hazelcast.config.ReplicatedMapConfig
- 
Deprecated.
new implementation doesn't use executor service for replication. 
 
- getRequest() - Method in class com.hazelcast.cluster.impl.operations.JoinRequestOperation
-  
- GetRequest - Class in com.hazelcast.concurrent.atomicreference.client
-  
- GetRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.GetRequest
-  
- GetRequest(String) - Constructor for class com.hazelcast.concurrent.atomicreference.client.GetRequest
-  
- getRequestDispatcher(String) - Method in class com.hazelcast.web.WebFilter.RequestWrapper
-  
- getRequestId() - Method in class com.hazelcast.internal.ascii.AbstractTextCommand
-  
- getRequestId() - Method in interface com.hazelcast.internal.ascii.TextCommand
-  
- getRequiredAction() - Method in class com.hazelcast.collection.impl.collection.client.CollectionAddAllRequest
-  
- getRequiredAction() - Method in class com.hazelcast.collection.impl.collection.client.CollectionAddRequest
-  
- getRequiredAction() - Method in class com.hazelcast.collection.impl.collection.client.CollectionClearRequest
-  
- getRequiredAction() - Method in class com.hazelcast.collection.impl.collection.client.CollectionCompareAndRemoveRequest
-  
- getRequiredAction() - Method in class com.hazelcast.collection.impl.collection.client.CollectionContainsRequest
-  
- getRequiredAction() - Method in class com.hazelcast.collection.impl.collection.client.CollectionGetAllRequest
-  
- getRequiredAction() - Method in class com.hazelcast.collection.impl.collection.client.CollectionIsEmptyRequest
-  
- getRequiredAction() - Method in class com.hazelcast.collection.impl.collection.client.CollectionRemoveRequest
-  
- getRequiredAction() - Method in class com.hazelcast.collection.impl.collection.client.CollectionRequest
-  
- getRequiredAction() - Method in class com.hazelcast.collection.impl.collection.client.CollectionSizeRequest
-  
- getRequiredAction() - Method in class com.hazelcast.collection.impl.list.client.ListGetRequest
-  
- getRequiredAction() - Method in class com.hazelcast.collection.impl.list.client.ListIndexOfRequest
-  
- getRequiredAction() - Method in class com.hazelcast.collection.impl.list.client.ListRemoveRequest
-  
- getRequiredAction() - Method in class com.hazelcast.collection.impl.list.client.ListSetRequest
-  
- getRequiredAction() - Method in class com.hazelcast.collection.impl.list.client.ListSubRequest
-  
- getRequiredMember() - Method in class com.hazelcast.config.TcpIpConfig
- 
Gets the required member. 
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.AbstractCacheRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheAddInvalidationListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheAddPartitionLostListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheClearRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheContainsKeyRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheCreateConfigRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheDestroyRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheEntryProcessorRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheGetAllRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheGetAndRemoveRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheGetRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheIterateRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheManagementConfigRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CachePutAllRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CachePutIfAbsentRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CachePutRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheRemoveEntryListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheRemoveInvalidationListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheRemovePartitionLostListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheRemoveRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheReplaceRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheSizeRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.client.AddDistributedObjectListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.client.AuthenticationRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.client.ClientCreateRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.client.ClientDestroyRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.client.GetDistributedObjectsRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.client.GetMemberListRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.client.RemoveAllListeners
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.client.RemoveDistributedObjectListenerRequest
-  
- getRequiredPermission() - Method in interface com.hazelcast.client.impl.client.SecureRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAddAndGetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterAndGetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongApplyMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongCompareAndSetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongDecrementAndGetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAddMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAlterMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndIncrementMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndSetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongIncrementAndGetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongSetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterAndGetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceApplyMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceClearMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceCompareAndSetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceContainsMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndAlterMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndSetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceIsNullMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetAndGetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationCustomCredentialsMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.AbstractCacheMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddEntryListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddInvalidationListenerTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheContainsKeyMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheCreateConfigMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheEntryProcessorMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndRemoveMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutIfAbsentMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CachePutMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionAwaitMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionBeforeAwaitMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchAwaitMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchCountDownMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchGetCountMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchTrySetCountMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.AbstractExecutorServiceCancelMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllWithIndexMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddWithIndexMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListClearMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRemoveAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRetainAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIndexOfMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIsEmptyMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIteratorMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListLastIndexOfMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListListIteratorMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveWithIndexMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSizeMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSubMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockForceUnlockMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockGetLockCountMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockGetRemainingLeaseTimeMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockIsLockedByCurrentThreadMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockIsLockedMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockLockMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockTryLockMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockUnlockMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapAddEntryListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapPutMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapQueryMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddIndexMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddInterceptorMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearNearCacheMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsKeyMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsValueMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapDeleteMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntrySetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnAllKeysMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeyMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeysMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteWithPredicateMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetEntryViewMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveEntryListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveIfSameMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveInterceptorMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemovePartitionLostListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSizeMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSubmitToKeyMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryLockMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryRemoveMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapUnlockMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.AbstractMapReduceTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceCancelMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceJobProcessInformationMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.AbstractMultiMapAddEntryListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapClearMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsEntryMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsKeyMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsValueMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapGetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapPutMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValueCountMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.NoSuchMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueClearMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRemoveAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRetainAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMaxSizeMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIsEmptyMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIteratorMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueOfferMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePeekMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePollMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePutMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemainingCapacityMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueSizeMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueTakeMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsKeyMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsValueMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapEntrySetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapIsEmptyMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapKeySetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapSizeMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapValuesMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferCapacityMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferHeadSequenceMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadManyMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadOneMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferRemainingCapacityMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferSizeMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferTailSequenceMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreAcquireMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreAvailablePermitsMessageTasks
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreDrainPermitsMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreInitMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreReducePermitsMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreReleaseMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreTryAcquireMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.set.SetClearMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRemoveAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRetainAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.set.SetGetAllMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.set.SetIsEmptyMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.set.SetSizeMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicAddMessageListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicPublishMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicRemoveMessageListenerMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCommitMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCreateMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionRollbackMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAClearRemoteTransactionMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XACollectTransactionsMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAFinalizeTransactionMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCommitMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCreateMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionPrepareMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionRollbackMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListAddMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListRemoveMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListSizeMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapContainsKeyMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapDeleteMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetForUpdateMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapIsEmptyMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetWithPredicateMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutIfAbsentMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveIfSameMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceIfSameMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSizeMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesWithPredicateMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapGetMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapPutMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveEntryMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapSizeMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapValueCountMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueOfferMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePeekMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePollMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueSizeMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueTakeMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetAddMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetRemoveMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetSizeMessageTask
-  
- getRequiredPermission() - Method in class com.hazelcast.cluster.client.AddMembershipListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cluster.client.ClientPingRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.cluster.client.RegisterMembershipListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.collection.client.CollectionAddListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.collection.client.CollectionRemoveListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.collection.client.CollectionRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.queue.client.AddAllRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.queue.client.AddListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.queue.client.ClearRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.queue.client.CompareAndRemoveRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.queue.client.DrainRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.queue.client.OfferRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.queue.client.PollRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.queue.client.QueueRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.queue.client.RemoveListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.queue.client.RemoveRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.txnlist.client.TxnListAddRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.txnlist.client.TxnListRemoveRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.txnlist.client.TxnListSizeRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnOfferRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnPeekRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnPollRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnSizeRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.txnset.client.TxnSetAddRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.txnset.client.TxnSetRemoveRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.collection.impl.txnset.client.TxnSetSizeRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.atomiclong.client.GetAndAddRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.atomiclong.client.ReadRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.atomicreference.client.AbstractAlterRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.atomicreference.client.ModifyRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.atomicreference.client.ReadRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.lock.client.AwaitRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.lock.client.BeforeAwaitRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.lock.client.IsLockedRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.lock.client.LockRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.lock.client.SignalRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.lock.client.UnlockRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.semaphore.client.AcquireRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.semaphore.client.AvailableRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.semaphore.client.DrainRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.semaphore.client.InitRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.semaphore.client.ReduceRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.concurrent.semaphore.client.ReleaseRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.executor.impl.client.CancellationRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.executor.impl.client.IsShutdownRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.executor.impl.client.PartitionTargetCallableRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.executor.impl.client.ShutdownRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.executor.impl.client.SpecificTargetCallableRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapAddIndexRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapAddPartitionLostListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapClearNearCacheRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapClearRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapContainsKeyRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapContainsValueRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapDeleteRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapEvictAllRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapEvictRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapFlushRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapGetAllRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapGetRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapIsEmptyRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapIsLockedRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapLockRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapPutAllRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapPutRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapRemoveEntryListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapRemovePartitionLostListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapSizeRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapUnlockRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.mapreduce.impl.client.ClientCancellationRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.mapreduce.impl.client.ClientJobProcessInformationRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.ClearRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.MultiMapAllPartitionRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.MultiMapIsLockedRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.MultiMapLockRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.MultiMapRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.MultiMapUnlockRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.PutRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.RemoveAllRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.RemoveEntryListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.RemoveRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapPutRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveAllRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.partition.client.AddPartitionLostListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.partition.client.GetPartitionsRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.partition.client.RemovePartitionLostListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapClearRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsKeyRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsValueRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapEntrySetRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapGetRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapIsEmptyRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapKeySetRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutTtlRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapSizeRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapValuesRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.ringbuffer.impl.client.AddAllRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.ringbuffer.impl.client.AddRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.ringbuffer.impl.client.CapacityRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.ringbuffer.impl.client.HeadSequenceRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.ringbuffer.impl.client.ReadManyRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.ringbuffer.impl.client.ReadOneRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.ringbuffer.impl.client.RemainingCapacityRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.ringbuffer.impl.client.SizeRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.ringbuffer.impl.client.TailSequenceRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.topic.impl.client.PublishRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.topic.impl.client.RemoveMessageListenerRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.transaction.client.BaseXATransactionRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.transaction.client.ClearRemoteTransactionRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.transaction.client.CollectXATransactionsRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.transaction.client.CommitTransactionRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.transaction.client.CreateTransactionRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.transaction.client.CreateXATransactionRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.transaction.client.FinalizeXATransactionRequest
-  
- getRequiredPermission() - Method in class com.hazelcast.transaction.client.RollbackTransactionRequest
-  
- getResource(String) - Method in class com.hazelcast.util.FilteringClassLoader
-  
- getResourceAdapter() - Method in class com.hazelcast.jca.ManagedConnectionFactoryImpl
-  
- getResourceAsStream(String) - Method in class com.hazelcast.util.FilteringClassLoader
-  
- getResources(String) - Method in class com.hazelcast.util.FilteringClassLoader
-  
- getResponse() - Method in class com.hazelcast.cache.impl.CacheClearResponse
-  
- getResponse() - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-  
- getResponse() - Method in class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
-  
- getResponse() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-  
- getResponse() - Method in class com.hazelcast.client.impl.client.ClientResponse
-  
- getResponse() - Method in class com.hazelcast.client.impl.operations.ClientReAuthOperation
-  
- getResponse() - Method in class com.hazelcast.client.impl.operations.GetConnectedClientsOperation
-  
- getResponse() - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-  
- getResponse() - Method in class com.hazelcast.cluster.impl.operations.AuthorizationOperation
-  
- getResponse() - Method in class com.hazelcast.cluster.impl.operations.ChangeClusterStateOperation
-  
- getResponse() - Method in class com.hazelcast.cluster.impl.operations.JoinCheckOperation
-  
- getResponse() - Method in class com.hazelcast.cluster.impl.operations.MasterClaimOperation
-  
- getResponse() - Method in class com.hazelcast.cluster.impl.operations.RollbackClusterStateOperation
-  
- getResponse() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
-  
- getResponse() - Method in class com.hazelcast.collection.impl.queue.operations.QueueOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.IsNullOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.countdownlatch.operations.GetCountOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.lock.operations.BaseLockOperation
-  
- getResponse() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
-  
- getResponse() - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
-  
- getResponse() - Method in class com.hazelcast.executor.impl.operations.ShutdownOperation
-  
- getResponse() - Method in class com.hazelcast.internal.management.operation.GetMapConfigOperation
-  
- getResponse() - Method in class com.hazelcast.internal.management.operation.ScriptExecutorOperation
-  
- getResponse() - Method in class com.hazelcast.internal.management.operation.ThreadDumpOperation
-  
- getResponse() - Method in class com.hazelcast.internal.management.operation.UpdateManagementCenterUrlOperation
-  
- getResponse() - Method in class com.hazelcast.internal.management.operation.UpdateMapConfigOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.AddIndexOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.ClearNearCacheOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.ClearOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.ContainsKeyOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.ContainsValueOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.DeleteOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.EntryOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.EvictOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.GetAllOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.GetEntryViewOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.GetOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.MapFlushOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.MapIsEmptyOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.MapSizeOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.MergeOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.MultipleEntryBackupOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.PartitionCheckIfLoadedOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryBackupOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.PutAllBackupOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.PutIfAbsentOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.PutOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.PutTransientOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.RemoveBackupOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.RemoveIfSameOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.ReplaceOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.SetOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.TryPutOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.query.QueryOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.query.QueryPartitionOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.tx.TxnLockAndGetOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.tx.TxnPrepareBackupOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.tx.TxnRollbackBackupOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.tx.TxnUnlockBackupOperation
-  
- getResponse() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-  
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.CancelJobSupervisorOperation
-  
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.FireNotificationOperation
-  
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.GetResultOperation
-  
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentOperation
-  
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.KeyValueJobOperation
-  
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.PostPonePartitionProcessing
-  
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.ProcessStatsUpdateOperation
-  
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.RequestMemberIdAssignment
-  
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionMapping
-  
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionProcessed
-  
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionReducing
-  
- getResponse() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-  
- getResponse() - Method in class com.hazelcast.partition.impl.AssignPartitions
-  
- getResponse() - Method in class com.hazelcast.partition.impl.BaseMigrationOperation
-  
- getResponse() - Method in class com.hazelcast.partition.impl.CheckReplicaVersion
-  
- getResponse() - Method in class com.hazelcast.partition.impl.HasOngoingMigration
-  
- getResponse() - Method in class com.hazelcast.partition.impl.IsReplicaVersionSync
-  
- getResponse() - Method in class com.hazelcast.partition.impl.MigrationOperation
-  
- getResponse() - Method in class com.hazelcast.partition.impl.MigrationRequestOperation
-  
- getResponse() - Method in class com.hazelcast.partition.impl.PartitionStateOperation
-  
- getResponse() - Method in class com.hazelcast.partition.impl.ReplicaSyncRequest
-  
- getResponse() - Method in class com.hazelcast.partition.impl.ReplicaSyncResponse
-  
- getResponse() - Method in class com.hazelcast.partition.impl.ReplicaSyncRetryResponse
-  
- getResponse() - Method in class com.hazelcast.partition.impl.SafeStateCheckOperation
-  
- getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
-  
- getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperation
-  
- getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.ContainsKeyOperation
-  
- getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.ContainsValueOperation
-  
- getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.EntrySetOperation
-  
- getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.GetOperation
-  
- getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.IsEmptyOperation
-  
- getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.KeySetOperation
-  
- getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.SizeOperation
-  
- getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.ValuesOperation
-  
- getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.VersionResponsePair
-  
- getResponse() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
-  
- getResponse() - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
-  
- getResponse() - Method in class com.hazelcast.ringbuffer.impl.operations.GenericOperation
-  
- getResponse() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadManyOperation
-  
- getResponse() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadOneOperation
-  
- getResponse() - Method in class com.hazelcast.spi.AbstractOperation
-  
- getResponse() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.DeregistrationOperation
-  
- getResponse() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.RegistrationOperation
-  
- getResponse() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
-  
- getResponse() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation
-  
- getResponse() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.DistributedObjectDestroyOperation
-  
- getResponse() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.InitializeDistributedObjectOperation
-  
- getResponse() - Method in class com.hazelcast.spi.Operation
-  
- getResponse() - Method in class com.hazelcast.transaction.impl.operations.BroadcastTxRollbackOperation
-  
- getResponse() - Method in class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
-  
- getResponse() - Method in class com.hazelcast.transaction.impl.operations.ReplicateTxBackupLogOperation
-  
- getResponse() - Method in class com.hazelcast.transaction.impl.operations.RollbackTxBackupLogOperation
-  
- getResponse() - Method in class com.hazelcast.transaction.impl.xa.operations.CollectRemoteTransactionsOperation
-  
- getResponseHandler() - Method in class com.hazelcast.spi.Operation
- 
Deprecated. 
- getResponseQueueSize() - Method in class com.hazelcast.jmx.OperationServiceMBean
-  
- getResponseQueueSize() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- getResponseQueueSize() - Method in interface com.hazelcast.spi.OperationService
- 
Deprecated. 
- getResponseTimeoutMillis() - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- getResult() - Method in class com.hazelcast.internal.metrics.renderers.CommaSeparatedKeyValueProbeRenderer
-  
- getResult() - Method in class com.hazelcast.internal.metrics.renderers.HumanFriendlyProbeRenderer
-  
- getResult() - Method in interface com.hazelcast.internal.metrics.renderers.ProbeRenderer
-  
- getResult(List<Future<Collection<QueryableEntry>>>) - Static method in class com.hazelcast.map.impl.query.MapQueryEngineImpl
-  
- getResult() - Method in class com.hazelcast.mapreduce.impl.operation.GetResultOperation
-  
- getResult() - Method in class com.hazelcast.query.impl.DefaultValueCollector
-  
- getResult() - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
- 
Returns:
 
 null - if cancelled or not done
 result - if done and result is NOT Throwable
 sneaky throws an exception - if done and result is Throwable
  
- GetResultOperation - Class in com.hazelcast.mapreduce.impl.operation
- 
This operation is used to retrieve results from a remote node 
- GetResultOperation() - Constructor for class com.hazelcast.mapreduce.impl.operation.GetResultOperation
-  
- GetResultOperation(String, String) - Constructor for class com.hazelcast.mapreduce.impl.operation.GetResultOperation
-  
- GetResultOperationFactory - Class in com.hazelcast.mapreduce.impl.operation
- 
- GetResultOperationFactory(String, String) - Constructor for class com.hazelcast.mapreduce.impl.operation.GetResultOperationFactory
-  
- getResults() - Method in class com.hazelcast.query.impl.getters.MultiResult
-  
- getResultSetInfo() - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getResultState() - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentResult
-  
- getResultState() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionResult
-  
- getRetryCount() - Method in class com.hazelcast.config.JobTrackerConfig
- 
retry count is currently not used but reserved for later use where the framework will
 automatically try to restart / retry operations from a available savepoint. 
- getRevision() - Method in class com.hazelcast.instance.BuildInfo
-  
- getRingbuffer(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getRingbuffer(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getRingbuffer() - Method in class com.hazelcast.client.proxy.ClientReliableTopicProxy
-  
- getRingbuffer(String) - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the distributed Ringbuffer instance with the specified name. 
- getRingbuffer(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getRingbuffer(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getRingbuffer(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getRingbufferConfig(String) - Method in class com.hazelcast.config.Config
-  
- getRingbufferConfigs() - Method in class com.hazelcast.config.Config
-  
- getRingEmptyWaitNotifyKey() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-  
- getRoleName() - Method in class com.hazelcast.jclouds.IAMRoleCredentialSupplierBuilder
-  
- getRows() - Method in class com.hazelcast.map.impl.query.QueryResult
-  
- getRunnable() - Method in class com.hazelcast.executor.impl.RunnableAdapter
-  
- getRunningOperationCount() - Method in class com.hazelcast.spi.impl.operationexecutor.classic.ClassicOperationExecutor
-  
- getRunningOperationCount() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
- 
Deprecated. 
- getRunningOperationsCount() - Method in class com.hazelcast.jmx.OperationServiceMBean
-  
- getRunningOperationsCount() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- getRunningOperationsCount() - Method in interface com.hazelcast.spi.OperationService
- 
Deprecated. 
- getRuntimeProps() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- getRuntimeProps() - Method in interface com.hazelcast.monitor.MemberState
-  
- getSafely() - Method in interface com.hazelcast.spi.InternalCompletableFuture
-  
- getSalt() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-  
- getScheduledDelayMillis() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
-  
- getScheduledExecutor(String) - Method in interface com.hazelcast.spi.ExecutionService
-  
- getScheduledExecutor(String) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-  
- getScheduledExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getScheduledReplicaSyncRequests() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- getScheduleId() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
-  
- getSchemeName() - Method in class com.hazelcast.internal.management.request.ChangeWanStateRequest
-  
- getScopedHost() - Method in class com.hazelcast.nio.Address
-  
- getScopeId() - Method in class com.hazelcast.nio.Address
-  
- getScopeId() - Method in class com.hazelcast.util.AddressUtil.AddressHolder
-  
- getScriptEngine() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineFactory
-  
- getScriptEngineManager() - Static method in class com.hazelcast.internal.management.ScriptEngineManagerContext
-  
- getSecond() - Method in class com.hazelcast.mapreduce.aggregation.impl.AvgTuple
-  
- getSeconds(HazelcastProperty) - Method in class com.hazelcast.instance.HazelcastProperties
- 
- getSecretKey() - Method in class com.hazelcast.config.AwsConfig
- 
Gets the secret key to access AWS. 
- getSecurityConfig() - Method in class com.hazelcast.client.config.ClientConfig
- 
- getSecurityConfig() - Method in class com.hazelcast.config.Config
-  
- getSecurityContext() - Method in interface com.hazelcast.client.ClientEngine
-  
- getSecurityContext() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- getSecurityContext() - Method in class com.hazelcast.instance.DefaultNodeExtension
-  
- getSecurityContext() - Method in interface com.hazelcast.instance.NodeExtension
- 
Returns SecurityContext for this Node if available, otherwise returns null. 
- getSecurityGroupName() - Method in class com.hazelcast.config.AwsConfig
- 
Gets the security group name. 
- getSecurityInterceptorConfigs() - Method in class com.hazelcast.config.SecurityConfig
-  
- getSegment(int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- getSegment(int) - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- getSegment(String, boolean) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-  
- getSelectionKey() - Method in class com.hazelcast.nio.tcp.nonblocking.AbstractHandler
-  
- getSelector() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingIOThread
- 
Gets the Selector 
- getSemaphore(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getSemaphore(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getSemaphore(String) - Method in interface com.hazelcast.core.HazelcastInstance
- 
Creates cluster-wide semaphore. 
- getSemaphore(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getSemaphore(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getSemaphore(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getSemaphoreConfig(String) - Method in class com.hazelcast.config.Config
- 
Returns the SemaphoreConfig for the given name 
- getSemaphoreConfigs() - Method in class com.hazelcast.config.Config
- 
Returns the collection of semaphore configs. 
- getSemaphoreContainer() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
-  
- getSemaphoreContainer(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-  
- getSendConnection() - Method in class com.hazelcast.client.spi.impl.ClientInvocation
-  
- getSendConnectionOrWait() - Method in class com.hazelcast.client.spi.impl.ClientInvocation
-  
- getSender() - Method in class com.hazelcast.mapreduce.impl.notification.LastChunkNotification
-  
- getSequence() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- getSequence() - Method in interface com.hazelcast.map.impl.querycache.event.sequence.Sequenced
- 
Returns the sequence number. 
- getSequence() - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- getSequence() - Method in interface com.hazelcast.map.impl.record.Record
- 
Only used for Hot Restart, HDRecord 
- getSerializationConfig() - Method in class com.hazelcast.client.config.ClientConfig
- 
- getSerializationConfig() - Method in class com.hazelcast.config.Config
-  
- getSerializationService() - Method in class com.hazelcast.cache.impl.nearcache.NearCacheContext
-  
- getSerializationService() - Method in interface com.hazelcast.client.ClientEngine
- 
Returns the SerializationService. 
- getSerializationService() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- getSerializationService() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- getSerializationService() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getSerializationService() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getSerializationService() - Method in class com.hazelcast.client.spi.ClientContext
-  
- getSerializationService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getSerializationService() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getSerializationService() - Method in class com.hazelcast.instance.Node
-  
- getSerializationService() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreContext
-  
- getSerializationService() - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- getSerializationService() - Method in interface com.hazelcast.nio.IOService
-  
- getSerializationService() - Method in class com.hazelcast.nio.NodeIOService
-  
- getSerializationService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getSerializationService() - Method in interface com.hazelcast.spi.impl.SerializationServiceSupport
-  
- getSerializationService() - Method in interface com.hazelcast.spi.NodeEngine
- 
Gets the SerializationService. 
- getSerializationType() - Method in class com.hazelcast.hibernate.serialization.Hibernate3CacheEntrySerializerHook
-  
- getSerializationType() - Method in class com.hazelcast.hibernate.serialization.Hibernate3CacheKeySerializerHook
-  
- getSerializationType() - Method in class com.hazelcast.hibernate.serialization.Hibernate4CacheEntrySerializerHook
-  
- getSerializationType() - Method in class com.hazelcast.hibernate.serialization.Hibernate4CacheKeySerializerHook
-  
- getSerializationType() - Method in interface com.hazelcast.nio.serialization.SerializerHook
- 
Returns the actual class type of the serialized object 
- getSerializationVersion() - Method in class com.hazelcast.instance.BuildInfo
-  
- getSerializerConfigs() - Method in class com.hazelcast.config.SerializationConfig
-  
- getServerRegistrationId() - Method in class com.hazelcast.client.spi.impl.listener.ClientEventRegistration
- 
Alias registration id is same as registration id in the beginning. 
- getServerSocketChannel() - Method in interface com.hazelcast.instance.AddressPicker
- 
Returns a server channel. 
- getService() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
-  
- getService() - Method in class com.hazelcast.client.impl.client.ClientRequest
-  
- getService(String) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-  
- getService() - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- getService() - Method in class com.hazelcast.spi.AbstractDistributedObject
- 
Gets the Service of this AbstractDistributedObject. 
- getService(String) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getService(String) - Method in class com.hazelcast.spi.impl.servicemanager.impl.ServiceManagerImpl
-  
- getService() - Method in class com.hazelcast.spi.impl.servicemanager.ServiceInfo
-  
- getService(String) - Method in interface com.hazelcast.spi.impl.servicemanager.ServiceManager
- 
Gets a Service by serviceName. 
- getService() - Method in class com.hazelcast.spi.Operation
-  
- getServiceConfig(String) - Method in class com.hazelcast.config.ServicesConfig
-  
- getServiceConfigs() - Method in class com.hazelcast.config.ServicesConfig
-  
- getServiceImpl() - Method in class com.hazelcast.config.ServiceConfig
-  
- getServiceInfo(String) - Method in class com.hazelcast.spi.impl.servicemanager.impl.ServiceManagerImpl
-  
- getServiceInfo(String) - Method in interface com.hazelcast.spi.impl.servicemanager.ServiceManager
- 
Gets the ServiceInfo for a service by serviceName. 
- getServiceInfos(Class) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getServiceInfos(Class) - Method in class com.hazelcast.spi.impl.servicemanager.impl.ServiceManagerImpl
- 
Returns a list of services matching provided service class/interface. 
- getServiceInfos(Class) - Method in interface com.hazelcast.spi.impl.servicemanager.ServiceManager
- 
Gets all the service info's for services that implement a given class/interface. 
- getServiceName() - Method in class com.hazelcast.cache.impl.CacheDistributedObject
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.client.AbstractCacheRequest
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheAddInvalidationListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheAddPartitionLostListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheClearRequest
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheCreateConfigRequest
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheDestroyRequest
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheIterateRequest
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheManagementConfigRequest
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CachePutAllRequest
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheRemoveEntryListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheRemoveInvalidationListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheRemovePartitionLostListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheSizeRequest
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
-  
- getServiceName() - Method in class com.hazelcast.cache.impl.operation.PostJoinCacheOperation
-  
- getServiceName() - Method in class com.hazelcast.client.impl.client.AddDistributedObjectListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.client.impl.client.AuthenticationRequest
-  
- getServiceName() - Method in class com.hazelcast.client.impl.client.ClientCreateRequest
-  
- getServiceName() - Method in class com.hazelcast.client.impl.client.ClientDestroyRequest
-  
- getServiceName() - Method in class com.hazelcast.client.impl.client.ClientRequest
-  
- getServiceName() - Method in class com.hazelcast.client.impl.client.DistributedObjectInfo
-  
- getServiceName() - Method in class com.hazelcast.client.impl.client.GetDistributedObjectsRequest
-  
- getServiceName() - Method in class com.hazelcast.client.impl.client.GetMemberListRequest
-  
- getServiceName() - Method in class com.hazelcast.client.impl.client.RemoveAllListeners
-  
- getServiceName() - Method in class com.hazelcast.client.impl.client.RemoveDistributedObjectListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.client.impl.operations.ClientReAuthOperation
-  
- getServiceName() - Method in class com.hazelcast.client.impl.operations.PostJoinClientOperation
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAddAndGetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterAndGetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongApplyMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongCompareAndSetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongDecrementAndGetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAddMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAlterMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndIncrementMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndSetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongIncrementAndGetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongSetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterAndGetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceApplyMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceClearMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceCompareAndSetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceContainsMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndAlterMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndSetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceIsNullMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetAndGetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationCustomCredentialsMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.AbstractCacheMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddEntryListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddInvalidationListenerTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheContainsKeyMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheCreateConfigMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionAwaitMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionBeforeAwaitMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.condition.ConditionSignalMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchAwaitMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchCountDownMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchGetCountMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.countdownlatch.CountDownLatchTrySetCountMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.AbstractExecutorServiceCancelMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToAddressMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddAllWithIndexMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddWithIndexMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListClearMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRemoveAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListCompareAndRetainAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListContainsMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListGetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIndexOfMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIsEmptyMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListIteratorMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListLastIndexOfMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListListIteratorMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListRemoveWithIndexMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSizeMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.list.ListSubMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockForceUnlockMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockGetLockCountMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockGetRemainingLeaseTimeMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockIsLockedByCurrentThreadMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockIsLockedMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockLockMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockTryLockMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.lock.LockUnlockMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapAddEntryListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapPutMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapQueryMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddIndexMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddInterceptorMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearNearCacheMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsKeyMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsValueMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapDeleteMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnAllKeysMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeyMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeysMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteWithPredicateMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetEntryViewMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveEntryListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveIfSameMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveInterceptorMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemovePartitionLostListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSizeMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapSubmitToKeyMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryLockMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapTryRemoveMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.map.MapUnlockMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.AbstractMapReduceTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceCancelMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceJobProcessInformationMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.AbstractMultiMapAddEntryListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapClearMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsEntryMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsKeyMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsValueMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapGetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapPutMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValueCountMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.NoSuchMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueClearMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRemoveAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueCompareAndRetainAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueContainsMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMaxSizeMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueDrainMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIsEmptyMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueIteratorMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueOfferMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePeekMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePollMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueuePutMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemainingCapacityMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueRemoveMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueSizeMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueTakeMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsKeyMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsValueMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapEntrySetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapIsEmptyMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapKeySetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapSizeMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapValuesMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferCapacityMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferHeadSequenceMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadManyMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadOneMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferRemainingCapacityMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferSizeMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferTailSequenceMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreAcquireMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreAvailablePermitsMessageTasks
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreDrainPermitsMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreInitMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreReducePermitsMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreReleaseMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreTryAcquireMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetClearMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRemoveAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRetainAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetContainsMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetGetAllMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetIsEmptyMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.set.SetSizeMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicAddMessageListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicPublishMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicRemoveMessageListenerMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCommitMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCreateMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionRollbackMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAClearRemoteTransactionMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XACollectTransactionsMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAFinalizeTransactionMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCommitMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCreateMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionPrepareMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionRollbackMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListAddMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListRemoveMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListSizeMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapContainsKeyMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapDeleteMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetForUpdateMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapIsEmptyMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetWithPredicateMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutIfAbsentMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveIfSameMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceIfSameMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSizeMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesWithPredicateMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapGetMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapPutMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveEntryMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapSizeMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapValueCountMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueOfferMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePeekMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePollMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueSizeMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueTakeMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetAddMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetRemoveMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetSizeMessageTask
-  
- getServiceName() - Method in class com.hazelcast.client.proxy.txn.ClientTxnListProxy
-  
- getServiceName() - Method in class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-  
- getServiceName() - Method in class com.hazelcast.client.proxy.txn.ClientTxnMultiMapProxy
-  
- getServiceName() - Method in class com.hazelcast.client.proxy.txn.ClientTxnQueueProxy
-  
- getServiceName() - Method in class com.hazelcast.client.proxy.txn.ClientTxnSetProxy
-  
- getServiceName() - Method in class com.hazelcast.client.spi.ClientProxy
-  
- getServiceName() - Method in class com.hazelcast.client.txn.proxy.ClientTxnListProxy
-  
- getServiceName() - Method in class com.hazelcast.client.txn.proxy.ClientTxnMapProxy
-  
- getServiceName() - Method in class com.hazelcast.client.txn.proxy.ClientTxnMultiMapProxy
-  
- getServiceName() - Method in class com.hazelcast.client.txn.proxy.ClientTxnQueueProxy
-  
- getServiceName() - Method in class com.hazelcast.client.txn.proxy.ClientTxnSetProxy
-  
- getServiceName() - Method in class com.hazelcast.cluster.client.AddMembershipListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.cluster.client.ClientPingRequest
-  
- getServiceName() - Method in class com.hazelcast.cluster.client.RegisterMembershipListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.cluster.impl.operations.ChangeClusterStateOperation
-  
- getServiceName() - Method in class com.hazelcast.cluster.impl.operations.LockClusterStateOperation
-  
- getServiceName() - Method in class com.hazelcast.cluster.impl.operations.RollbackClusterStateOperation
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.collection.client.CollectionAddListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.collection.client.CollectionRemoveListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.collection.client.CollectionRequest
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.collection.CollectionService
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.list.ListService
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.queue.client.AddListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.queue.client.QueueRequest
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.queue.client.RemoveListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.queue.operations.QueueOperation
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.queue.operations.QueueReplicationOperation
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.set.SetProxyImpl
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.set.SetService
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.txnlist.client.TxnListAddRequest
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.txnlist.client.TxnListRemoveRequest
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.txnlist.client.TxnListSizeRequest
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.txnlist.TransactionalListProxy
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnOfferRequest
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnPeekRequest
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnPollRequest
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnSizeRequest
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxySupport
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.txnset.client.TxnSetAddRequest
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.txnset.client.TxnSetRemoveRequest
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.txnset.client.TxnSetSizeRequest
-  
- getServiceName() - Method in class com.hazelcast.collection.impl.txnset.TransactionalSetProxy
-  
- getServiceName() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- getServiceName() - Method in class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
-  
- getServiceName() - Method in class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
-  
- getServiceName() - Method in class com.hazelcast.concurrent.atomiclong.client.ReadRequest
-  
- getServiceName() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
-  
- getServiceName() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
-  
- getServiceName() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- getServiceName() - Method in class com.hazelcast.concurrent.atomicreference.client.AbstractAlterRequest
-  
- getServiceName() - Method in class com.hazelcast.concurrent.atomicreference.client.ModifyRequest
-  
- getServiceName() - Method in class com.hazelcast.concurrent.atomicreference.client.ReadRequest
-  
- getServiceName() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
-  
- getServiceName() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
-  
- getServiceName() - Method in class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-  
- getServiceName() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-  
- getServiceName() - Method in class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-  
- getServiceName() - Method in class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-  
- getServiceName() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
-  
- getServiceName() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
-  
- getServiceName() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorImpl
-  
- getServiceName() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorProxy
-  
- getServiceName() - Method in class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-  
- getServiceName() - Method in class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-  
- getServiceName() - Method in class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-  
- getServiceName() - Method in class com.hazelcast.concurrent.lock.client.AwaitRequest
-  
- getServiceName() - Method in class com.hazelcast.concurrent.lock.client.BeforeAwaitRequest
-  
- getServiceName() - Method in class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-  
- getServiceName() - Method in class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-  
- getServiceName() - Method in class com.hazelcast.concurrent.lock.client.SignalRequest
-  
- getServiceName() - Method in class com.hazelcast.concurrent.lock.ConditionKey
-  
- getServiceName() - Method in class com.hazelcast.concurrent.lock.InternalLockNamespace
-  
- getServiceName() - Method in class com.hazelcast.concurrent.lock.LockProxy
-  
- getServiceName() - Method in class com.hazelcast.concurrent.lock.LockWaitNotifyKey
-  
- getServiceName() - Method in class com.hazelcast.concurrent.lock.operations.BaseLockOperation
-  
- getServiceName() - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
-  
- getServiceName() - Method in class com.hazelcast.concurrent.semaphore.client.SemaphoreRequest
-  
- getServiceName() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
-  
- getServiceName() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
-  
- getServiceName() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-  
- getServiceName() - Method in interface com.hazelcast.core.DistributedObject
- 
Returns the service name for this object. 
- getServiceName() - Method in class com.hazelcast.core.DistributedObjectEvent
- 
Returns the service name of related DistributedObject. 
- getServiceName() - Method in class com.hazelcast.executor.impl.client.CancellationRequest
-  
- getServiceName() - Method in class com.hazelcast.executor.impl.client.IsShutdownRequest
-  
- getServiceName() - Method in class com.hazelcast.executor.impl.client.PartitionTargetCallableRequest
-  
- getServiceName() - Method in class com.hazelcast.executor.impl.client.ShutdownRequest
-  
- getServiceName() - Method in class com.hazelcast.executor.impl.client.SpecificTargetCallableRequest
-  
- getServiceName() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- getServiceName() - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
-  
- getServiceName() - Method in class com.hazelcast.executor.impl.operations.ShutdownOperation
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapAddIndexRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapAddPartitionLostListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapClearNearCacheRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapClearRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapContainsKeyRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapContainsValueRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapDeleteRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapEvictAllRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapEvictRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapFlushRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapGetAllRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapGetRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapIsEmptyRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapPutAllRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapPutRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapRemoveEntryListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapRemovePartitionLostListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapSizeRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-  
- getServiceName() - Method in class com.hazelcast.map.impl.operation.AddIndexOperation
-  
- getServiceName() - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperation
-  
- getServiceName() - Method in class com.hazelcast.map.impl.operation.ClearExpiredOperation
-  
- getServiceName() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-  
- getServiceName() - Method in class com.hazelcast.map.impl.operation.MapOperation
-  
- getServiceName() - Method in class com.hazelcast.map.impl.operation.MapReplicationOperation
-  
- getServiceName() - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
-  
- getServiceName() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-  
- getServiceName() - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-  
- getServiceName() - Method in class com.hazelcast.mapreduce.impl.client.ClientCancellationRequest
-  
- getServiceName() - Method in class com.hazelcast.mapreduce.impl.client.ClientJobProcessInformationRequest
-  
- getServiceName() - Method in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-  
- getServiceName() - Method in class com.hazelcast.mapreduce.impl.operation.KeyValueJobOperation
-  
- getServiceName() - Method in class com.hazelcast.mapreduce.impl.operation.ProcessingOperation
-  
- getServiceName() - Method in class com.hazelcast.mapreduce.impl.operation.StartProcessingJobOperation
-  
- getServiceName() - Method in class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.multimap.impl.client.MultiMapAllPartitionRequest
-  
- getServiceName() - Method in class com.hazelcast.multimap.impl.client.MultiMapRequest
-  
- getServiceName() - Method in class com.hazelcast.multimap.impl.client.RemoveEntryListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRequest
-  
- getServiceName() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-  
- getServiceName() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-  
- getServiceName() - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-  
- getServiceName() - Method in class com.hazelcast.partition.client.AddPartitionLostListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.partition.client.GetPartitionsRequest
-  
- getServiceName() - Method in class com.hazelcast.partition.client.RemovePartitionLostListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.partition.impl.CheckReplicaVersion
-  
- getServiceName() - Method in class com.hazelcast.partition.impl.HasOngoingMigration
-  
- getServiceName() - Method in class com.hazelcast.partition.impl.PartitionStateOperation
-  
- getServiceName() - Method in class com.hazelcast.partition.impl.ReplicaSyncResponse
-  
- getServiceName() - Method in class com.hazelcast.partition.impl.ReplicaSyncRetryResponse
-  
- getServiceName() - Method in class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-  
- getServiceName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapClearRequest
-  
- getServiceName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-  
- getServiceName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperation
-  
- getServiceName() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicationOperation
-  
- getServiceName() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-  
- getServiceName() - Method in class com.hazelcast.ringbuffer.impl.client.AddAllRequest
-  
- getServiceName() - Method in class com.hazelcast.ringbuffer.impl.client.RingbufferRequest
-  
- getServiceName() - Method in class com.hazelcast.ringbuffer.impl.operations.AbstractRingBufferOperation
-  
- getServiceName() - Method in class com.hazelcast.ringbuffer.impl.operations.ReplicationOperation
-  
- getServiceName() - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
-  
- getServiceName() - Method in class com.hazelcast.spi.AbstractDistributedObject
-  
- getServiceName() - Method in class com.hazelcast.spi.AbstractWaitNotifyKey
-  
- getServiceName() - Method in class com.hazelcast.spi.DefaultObjectNamespace
-  
- getServiceName() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventEnvelope
-  
- getServiceName() - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
-  
- getServiceName() - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
-  
- getServiceName() - Method in class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectEventPacket
-  
- getServiceName() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.InitializeDistributedObjectOperation
-  
- getServiceName() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.PostJoinProxyOperation
-  
- getServiceName() - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyInfo
-  
- getServiceName() - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyRegistry
- 
Returns the name of the service for this ProxyRegistry. 
- getServiceName() - Method in class com.hazelcast.spi.InvocationBuilder
- 
Gets the name of the service. 
- getServiceName() - Method in interface com.hazelcast.spi.ObjectNamespace
- 
Gets the service name. 
- getServiceName() - Method in class com.hazelcast.spi.Operation
-  
- getServiceName() - Method in interface com.hazelcast.spi.WaitNotifyKey
- 
Returns the service name of the wait notify object for this key. 
- getServiceName() - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.topic.impl.client.PublishRequest
-  
- getServiceName() - Method in class com.hazelcast.topic.impl.client.RemoveMessageListenerRequest
-  
- getServiceName() - Method in class com.hazelcast.topic.impl.PublishOperation
-  
- getServiceName() - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicProxy
-  
- getServiceName() - Method in class com.hazelcast.topic.impl.TopicProxySupport
-  
- getServiceName() - Method in class com.hazelcast.transaction.client.BaseXATransactionRequest
-  
- getServiceName() - Method in class com.hazelcast.transaction.client.ClearRemoteTransactionRequest
-  
- getServiceName() - Method in class com.hazelcast.transaction.client.CollectXATransactionsRequest
-  
- getServiceName() - Method in class com.hazelcast.transaction.client.CommitTransactionRequest
-  
- getServiceName() - Method in class com.hazelcast.transaction.client.CreateTransactionRequest
-  
- getServiceName() - Method in class com.hazelcast.transaction.client.CreateXATransactionRequest
-  
- getServiceName() - Method in class com.hazelcast.transaction.client.FinalizeXATransactionRequest
-  
- getServiceName() - Method in class com.hazelcast.transaction.client.RollbackTransactionRequest
-  
- getServiceName() - Method in class com.hazelcast.transaction.impl.operations.TxBaseOperation
-  
- getServiceName() - Method in class com.hazelcast.transaction.impl.xa.operations.BaseXAOperation
-  
- getServiceName() - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
-  
- getServiceName() - Method in class com.hazelcast.wan.WanReplicationEvent
- 
Returns the service name for this event object. 
- getServicePort() - Method in class com.hazelcast.jclouds.ComputeServiceBuilder
-  
- getServices(Class<S>) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
- 
Returns a list of services matching provides service class/interface. 
- getServices(Class<S>) - Method in class com.hazelcast.spi.impl.servicemanager.impl.ServiceManagerImpl
-  
- getServices(Class<S>) - Method in interface com.hazelcast.spi.impl.servicemanager.ServiceManager
- 
Gets all services implementing a certain class/interface. 
- getServicesConfig() - Method in class com.hazelcast.config.Config
-  
- getServletContext() - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- getSession() - Method in class com.hazelcast.web.WebFilter.RequestWrapper
-  
- getSession(boolean) - Method in class com.hazelcast.web.WebFilter.RequestWrapper
-  
- getSessionContext() - Method in class com.hazelcast.web.HazelcastHttpSession
- 
Deprecated. 
- GetSessionStateEntryProcessor - Class in com.hazelcast.web.entryprocessor
- 
Entry processor which return SessionState object stored in distributed map 
- GetSessionStateEntryProcessor() - Constructor for class com.hazelcast.web.entryprocessor.GetSessionStateEntryProcessor
-  
- getSet() - Method in class com.hazelcast.client.console.ClientConsoleApp
-  
- getSet(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getSet(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getSet(String) - Method in class com.hazelcast.client.proxy.txn.TransactionContextProxy
-  
- getSet(String) - Method in class com.hazelcast.client.proxy.txn.xa.XATransactionContextProxy
-  
- getSet(String) - Method in class com.hazelcast.client.txn.proxy.xa.XATransactionContextProxy
-  
- getSet(String) - Method in class com.hazelcast.client.txn.TransactionContextProxy
-  
- getSet() - Method in class com.hazelcast.console.ConsoleApp
-  
- getSet(String) - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the distributed set instance with the specified name. 
- getSet(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getSet(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getSet(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getSet(String) - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
-  
- getSet(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
- 
Returns the transactional set instance with the specified name. 
- getSetConfig(String) - Method in class com.hazelcast.config.Config
-  
- getSetConfigs() - Method in class com.hazelcast.config.Config
-  
- getSetName() - Method in class com.hazelcast.mapreduce.impl.SetKeyValueSource
-  
- getSharedService(String) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getSharedService(String) - Method in class com.hazelcast.spi.impl.servicemanager.impl.ServiceManagerImpl
-  
- getSharedService(String) - Method in interface com.hazelcast.spi.impl.servicemanager.ServiceManager
- 
Gets a SharedService by serviceName. 
- getSharedService(String) - Method in interface com.hazelcast.spi.NodeEngine
- 
- getShort(int) - Method in interface com.hazelcast.client.impl.protocol.util.ClientProtocolBuffer
- 
Get the value at a given index. 
- getShort(int) - Method in class com.hazelcast.client.impl.protocol.util.SafeBuffer
-  
- getShort(int) - Method in class com.hazelcast.client.impl.protocol.util.UnsafeBuffer
-  
- getShortAttribute(String) - Method in class com.hazelcast.client.impl.MemberImpl
-  
- getShortAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-  
- getShortAttribute(String) - Method in interface com.hazelcast.core.Member
- 
Returns the value of the specified key for this member or
 null if value is undefined. 
- getShortAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-  
- getSignalKey(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- getSignedHeaders() - Method in class com.hazelcast.aws.security.EC2RequestSigner
-  
- getSingleType() - Method in enum com.hazelcast.nio.serialization.FieldType
-  
- getSize() - Method in interface com.hazelcast.client.spi.ClientClusterService
- 
Gets the current number of members. 
- getSize(MemberSelector) - Method in interface com.hazelcast.client.spi.ClientClusterService
- 
Gets the number of members that satisfy the given  MemberSelector instance. 
- getSize() - Method in class com.hazelcast.client.spi.impl.ClientClusterServiceImpl
-  
- getSize(MemberSelector) - Method in class com.hazelcast.client.spi.impl.ClientClusterServiceImpl
-  
- getSize() - Method in interface com.hazelcast.cluster.ClusterService
- 
Gets the current number of members. 
- getSize(MemberSelector) - Method in interface com.hazelcast.cluster.ClusterService
- 
Gets the number of members that satisfy the given  MemberSelector instance. 
- getSize() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- getSize(MemberSelector) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- getSize() - Method in class com.hazelcast.config.EvictionConfig
-  
- getSize() - Method in class com.hazelcast.config.MaxSizeConfig
- 
Returns the size of the map. 
- getSize() - Method in class com.hazelcast.config.NativeMemoryConfig
-  
- getSize() - Method in class com.hazelcast.config.QuorumConfig
-  
- getSize() - Method in class com.hazelcast.jmx.MapMBean
-  
- getSize() - Method in class com.hazelcast.jmx.MultiMapMBean
-  
- getSize() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- getSize() - Method in class com.hazelcast.map.impl.nearcache.NearCacheSizeEstimator
-  
- getSize() - Method in interface com.hazelcast.map.impl.SizeEstimator
-  
- getSize() - Method in class com.hazelcast.quorum.impl.QuorumImpl
-  
- getSizeEstimator() - Method in interface com.hazelcast.map.impl.recordstore.Storage
-  
- getSizeInMemory() - Method in class com.hazelcast.hibernate.distributed.IMapRegionCache
-  
- getSizeInMemory() - Method in class com.hazelcast.hibernate.local.LocalRegionCache
-  
- getSizeInMemory() - Method in interface com.hazelcast.hibernate.RegionCache
-  
- getSlowOperationDTOs() - Method in class com.hazelcast.spi.impl.operationexecutor.slowoperationdetector.SlowOperationDetector
-  
- getSlowOperationDTOs() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- getSlowOperationDTOs() - Method in interface com.hazelcast.spi.impl.operationservice.InternalOperationService
- 
Returns information about long running operations. 
- getSlowOperations() - Method in class com.hazelcast.monitor.impl.LocalOperationStatsImpl
-  
- getSocketAddress() - Method in class com.hazelcast.client.ClientEvent
-  
- getSocketAddress() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- getSocketAddress() - Method in class com.hazelcast.client.impl.ClientImpl
-  
- getSocketAddress() - Method in interface com.hazelcast.core.Client
- 
Returns the socket address of this client. 
- getSocketAddress() - Method in interface com.hazelcast.core.Endpoint
- 
Returns the socket address for this endpoint. 
- getSocketAddress() - Method in interface com.hazelcast.core.Member
- 
Returns the socket address of this member. 
- getSocketAddress() - Method in class com.hazelcast.instance.AbstractMember
-  
- getSocketAddresses(String) - Static method in class com.hazelcast.client.util.AddressHelper
-  
- getSocketChannelWrapper() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- getSocketChannelWrapper() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- getSocketChannelWrapperFactory() - Method in class com.hazelcast.instance.DefaultNodeExtension
-  
- getSocketChannelWrapperFactory() - Method in interface com.hazelcast.instance.NodeExtension
- 
Returns SocketChannelWrapperFactory instance to be used by this Node. 
- getSocketChannelWrapperFactory() - Method in interface com.hazelcast.nio.IOService
-  
- getSocketChannelWrapperFactory() - Method in class com.hazelcast.nio.NodeIOService
-  
- getSocketClientReceiveBufferSize() - Method in interface com.hazelcast.nio.IOService
- 
Size of receive buffers for connections opened by clients 
- getSocketClientReceiveBufferSize() - Method in class com.hazelcast.nio.NodeIOService
-  
- getSocketClientSendBufferSize() - Method in interface com.hazelcast.nio.IOService
- 
Size of send buffers for connections opened by clients 
- getSocketClientSendBufferSize() - Method in class com.hazelcast.nio.NodeIOService
-  
- getSocketConnectTimeoutSeconds() - Method in interface com.hazelcast.nio.IOService
-  
- getSocketConnectTimeoutSeconds() - Method in class com.hazelcast.nio.NodeIOService
-  
- getSocketInterceptorConfig() - Method in class com.hazelcast.client.config.ClientConfig
- 
Deprecated. 
- getSocketInterceptorConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-  
- getSocketInterceptorConfig() - Method in class com.hazelcast.config.NetworkConfig
- 
- getSocketInterceptorConfig() - Method in interface com.hazelcast.nio.IOService
-  
- getSocketInterceptorConfig() - Method in class com.hazelcast.nio.NodeIOService
-  
- getSocketKeepAlive() - Method in interface com.hazelcast.nio.IOService
-  
- getSocketKeepAlive() - Method in class com.hazelcast.nio.NodeIOService
-  
- getSocketLingerSeconds() - Method in interface com.hazelcast.nio.IOService
-  
- getSocketLingerSeconds() - Method in class com.hazelcast.nio.NodeIOService
-  
- getSocketNoDelay() - Method in interface com.hazelcast.nio.IOService
-  
- getSocketNoDelay() - Method in class com.hazelcast.nio.NodeIOService
-  
- getSocketOptions() - Method in class com.hazelcast.client.config.ClientConfig
- 
Deprecated. 
- getSocketOptions() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-  
- getSocketReader() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- getSocketReceiveBufferSize() - Method in interface com.hazelcast.nio.IOService
-  
- getSocketReceiveBufferSize() - Method in class com.hazelcast.nio.NodeIOService
-  
- getSocketSendBufferSize() - Method in interface com.hazelcast.nio.IOService
-  
- getSocketSendBufferSize() - Method in class com.hazelcast.nio.NodeIOService
-  
- getSocketWriter() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- getSortedQueryResultSet(List<Map.Entry>, PagingPredicate, IterationType) - Static method in class com.hazelcast.util.SortingUtil
-  
- getSortedSubList(List<QueryableEntry>, PagingPredicate, Map.Entry<Integer, Map.Entry>) - Static method in class com.hazelcast.util.SortingUtil
-  
- getSource() - Method in class com.hazelcast.cache.impl.event.AbstractICacheEvent
- 
Returns the object on which the event initially occurred. 
- getSource() - Method in class com.hazelcast.core.AbstractIMapEvent
- 
Returns the object on which the event initially occurred. 
- getSource() - Method in interface com.hazelcast.map.impl.event.EventData
-  
- getSource() - Method in class com.hazelcast.map.impl.mapstore.writebehind.StoreEvent
-  
- getSource() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- getSource() - Method in class com.hazelcast.partition.MigrationInfo
-  
- getSource() - Method in class com.hazelcast.spi.impl.PortablePartitionLostEvent
-  
- getSourceUuid() - Method in class com.hazelcast.cache.impl.client.CacheInvalidationMessage
-  
- getSourceUuid() - Method in class com.hazelcast.cache.impl.client.CacheSingleInvalidationMessage
-  
- getSourceUuid() - Method in class com.hazelcast.map.impl.nearcache.Invalidation
-  
- getSpecificationName() - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-  
- getSpecificationVendor() - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-  
- getSpecificationVersion() - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-  
- getSql() - Method in class com.hazelcast.config.PredicateConfig
- 
Returns sql string for this config. 
- getSSLConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
- 
- getSSLConfig() - Method in class com.hazelcast.config.NetworkConfig
- 
- getSSLConfig() - Method in interface com.hazelcast.nio.IOService
-  
- getSSLConfig() - Method in class com.hazelcast.nio.NodeIOService
-  
- getSSLContext() - Method in class com.hazelcast.nio.ssl.BasicSSLContextFactory
-  
- getSSLContext() - Method in interface com.hazelcast.nio.ssl.SSLContextFactory
-  
- getStartedTaskCount() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-  
- getStartedTaskCount() - Method in interface com.hazelcast.monitor.LocalExecutorStats
- 
Returns the number of started operations on the executor service. 
- getStartTime() - Method in class com.hazelcast.cluster.impl.AbstractJoiner
-  
- getStartTime() - Method in interface com.hazelcast.cluster.Joiner
-  
- getStartTime() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-  
- getStartTime() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
-  
- getStartTime() - Method in class com.hazelcast.transaction.impl.xa.XATransactionDTO
-  
- getState() - Method in class com.hazelcast.client.proxy.txn.xa.XATransactionProxy
-  
- getState() - Method in class com.hazelcast.client.txn.proxy.xa.XATransactionProxy
-  
- getState() - Method in class com.hazelcast.cluster.impl.ClusterStateManager
-  
- getState() - Method in class com.hazelcast.core.LifecycleEvent
-  
- getState() - Method in class com.hazelcast.instance.Node
- 
Returns the node state. 
- getState() - Method in class com.hazelcast.mapreduce.impl.task.JobPartitionStateImpl
-  
- getState() - Method in interface com.hazelcast.mapreduce.JobPartitionState
- 
Returns the current processing state of this partition 
- getState() - Method in interface com.hazelcast.transaction.impl.Transaction
-  
- getState() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-  
- getState() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
-  
- getStatistics(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- getStatistics(String) - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- getStatistics() - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- getStatistics() - Method in interface com.hazelcast.map.impl.record.Record
-  
- getStatistics() - Method in class com.hazelcast.map.impl.record.RecordInfo
-  
- getStats() - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- getStats() - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-  
- getStats() - Method in interface com.hazelcast.internal.ascii.TextCommandService
-  
- getStats() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- getStats() - Method in class com.hazelcast.map.impl.MapService
-  
- getStats() - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- getStats() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-  
- getStats() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- getStats() - Method in interface com.hazelcast.spi.StatisticsAwareService
-  
- getStats() - Method in class com.hazelcast.topic.impl.TopicService
-  
- getStats() - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
-  
- getStatsMap() - Method in class com.hazelcast.topic.impl.TopicService
-  
- getStatus() - Method in class com.hazelcast.core.MigrationEvent
- 
Returns the status of the migration: started, completed or failed 
- getStorage() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- getStorage() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-  
- getStorage() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- getStorageRef() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-  
- getStore() - Method in class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
-  
- getStoreImplementation() - Method in class com.hazelcast.config.QueueStoreConfig
-  
- getStores() - Method in class com.hazelcast.replicatedmap.impl.PartitionContainer
-  
- getStoreTime() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntry
-  
- getString(HazelcastProperty) - Method in class com.hazelcast.instance.HazelcastProperties
- 
- getString(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
- 
Returns a field in a Json object as a string. 
- getString(JsonObject, String, String) - Static method in class com.hazelcast.util.JsonUtil
- 
Returns a field in a Json object as a string. 
- getStringAttribute(String) - Method in class com.hazelcast.client.impl.MemberImpl
-  
- getStringAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-  
- getStringAttribute(String) - Method in interface com.hazelcast.core.Member
- 
Returns the value of the specified key for this member or
 null if value is undefined. 
- getStringAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-  
- getStringUtf8(int, int) - Method in interface com.hazelcast.client.impl.protocol.util.ClientProtocolBuffer
- 
Get part of String from bytes encoded in UTF-8 format without a length prefix. 
- getStringUtf8() - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- getStringUtf8(int, int) - Method in class com.hazelcast.client.impl.protocol.util.SafeBuffer
-  
- getStringUtf8(int, int) - Method in class com.hazelcast.client.impl.protocol.util.UnsafeBuffer
-  
- getSubject() - Method in interface com.hazelcast.client.ClientEndpoint
-  
- getSubject() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- getSubRecords(ComparisonType, Comparable) - Method in interface com.hazelcast.query.impl.Index
-  
- getSubRecords(ComparisonType, Comparable) - Method in class com.hazelcast.query.impl.IndexImpl
-  
- getSubRecords(ComparisonType, Comparable) - Method in interface com.hazelcast.query.impl.IndexStore
-  
- getSubRecords(ComparisonType, Comparable) - Method in class com.hazelcast.query.impl.SortedIndexStore
-  
- getSubRecords(ComparisonType, Comparable) - Method in class com.hazelcast.query.impl.UnsortedIndexStore
-  
- getSubRecordsBetween(Comparable, Comparable) - Method in interface com.hazelcast.query.impl.Index
-  
- getSubRecordsBetween(Comparable, Comparable) - Method in class com.hazelcast.query.impl.IndexImpl
-  
- getSubRecordsBetween(Comparable, Comparable) - Method in interface com.hazelcast.query.impl.IndexStore
-  
- getSubRecordsBetween(Comparable, Comparable) - Method in class com.hazelcast.query.impl.SortedIndexStore
-  
- getSubRecordsBetween(Comparable, Comparable) - Method in class com.hazelcast.query.impl.UnsortedIndexStore
-  
- getSubscriber() - Method in class com.hazelcast.client.spi.impl.listener.ClientEventRegistration
- 
This is used when removing the listener. 
- getSubscriber() - Method in interface com.hazelcast.spi.EventRegistration
- 
Returns the subscriber of this registration. 
- getSubscriber() - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
-  
- getSymmetricEncryptionConfig() - Method in class com.hazelcast.config.NetworkConfig
- 
- getSymmetricEncryptionConfig() - Method in interface com.hazelcast.nio.IOService
-  
- getSymmetricEncryptionConfig() - Method in class com.hazelcast.nio.NodeIOService
-  
- getSyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionBackupAwareOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.collection.impl.queue.operations.QueueBackupAwareOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.concurrent.lock.operations.BaseLockOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupAwareOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-  
- getSyncBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
- 
Deprecated. 
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.BasePutOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.ClearOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EntryOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EvictOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.MapFlushOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
-  
- getSyncBackupCount() - Method in interface com.hazelcast.spi.BackupAwareOperation
- 
The synchronous backup count. 
- getSyncBackupCount() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
-  
- getSyncBackupCount() - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionOperation
-  
- getSystemExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getSystemLoadAverage() - Static method in class com.hazelcast.util.OperatingSystemMXBeanSupport
- 
Reads the system load average attribute from OperatingSystemMXBean. 
- getSystemProperty() - Method in enum com.hazelcast.client.config.ClientProperty
-  
- getSystemProperty() - Method in enum com.hazelcast.instance.GroupProperty
-  
- getSystemProperty() - Method in interface com.hazelcast.instance.HazelcastProperty
- 
Gets the environmental value of the property. 
- GetSystemWarningsRequest - Class in com.hazelcast.internal.management.request
- 
Deprecated. 
- GetSystemWarningsRequest() - Constructor for class com.hazelcast.internal.management.request.GetSystemWarningsRequest
- 
Deprecated. 
- getTableIndex() - Method in class com.hazelcast.cache.impl.CacheKeyIteratorResult
-  
- getTagKey() - Method in class com.hazelcast.config.AwsConfig
- 
Gets the tag key. 
- getTagPairs() - Method in class com.hazelcast.jclouds.ComputeServiceBuilder
-  
- getTagValue() - Method in class com.hazelcast.config.AwsConfig
- 
Gets the tag value. 
- getTarget() - Method in class com.hazelcast.cluster.impl.ClusterStateTransactionLogRecord
-  
- getTarget() - Method in class com.hazelcast.executor.impl.client.SpecificTargetCallableRequest
-  
- getTarget() - Method in exception com.hazelcast.spi.exception.WrongTargetException
-  
- getTarget() - Method in class com.hazelcast.spi.impl.operationservice.impl.PartitionInvocation
-  
- getTarget() - Method in class com.hazelcast.spi.impl.operationservice.impl.TargetInvocation
-  
- getTarget() - Method in class com.hazelcast.spi.InvocationBuilder
- 
Returns the target machine. 
- getTarget() - Method in interface com.hazelcast.transaction.impl.TargetAwareTransactionLogRecord
- 
Returns target of changes made by this transaction record. 
- getTargetAddress() - Method in class com.hazelcast.cluster.impl.AbstractJoiner
-  
- getTargetAddress() - Method in class com.hazelcast.cluster.impl.BindMessage
-  
- getTargetClusterConfigs() - Method in class com.hazelcast.config.WanReplicationConfig
-  
- getTargetExecutionCallback() - Method in class com.hazelcast.spi.InvocationBuilder
-  
- getTargetObject(boolean) - Method in class com.hazelcast.query.impl.CachedQueryEntry
-  
- getTargetObject(boolean) - Method in class com.hazelcast.query.impl.QueryableEntry
-  
- getTargetObject(boolean) - Method in class com.hazelcast.query.impl.QueryEntry
-  
- getTargets() - Method in class com.hazelcast.client.impl.client.MultiTargetClientRequest
-  
- getTargets() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMultiTargetMessageTask
-  
- getTargets() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddInterceptorMessageTask
-  
- getTargets() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveInterceptorMessageTask
-  
- getTargets() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XACollectTransactionsMessageTask
-  
- getTargets() - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-  
- getTargets() - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-  
- getTargets() - Method in class com.hazelcast.transaction.client.CollectXATransactionsRequest
-  
- getTasks() - Method in class com.hazelcast.client.impl.protocol.MessageTaskFactoryImpl
-  
- getTcpIpConfig() - Method in class com.hazelcast.config.JoinConfig
-  
- GetterFactory - Class in com.hazelcast.query.impl.getters
-  
- getTextCommandService() - Method in class com.hazelcast.instance.Node
-  
- getTextCommandService() - Method in interface com.hazelcast.nio.IOService
-  
- getTextCommandService() - Method in class com.hazelcast.nio.NodeIOService
-  
- getTextContent(Node) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-  
- getTextWriteHandler() - Method in class com.hazelcast.nio.ascii.TextReadHandler
-  
- getThisAddress() - Method in interface com.hazelcast.client.ClientEngine
-  
- getThisAddress() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- getThisAddress() - Method in interface com.hazelcast.cluster.ClusterService
- 
Gets the address of this member. 
- getThisAddress() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- getThisAddress() - Method in class com.hazelcast.instance.Node
-  
- getThisAddress() - Method in interface com.hazelcast.nio.IOService
-  
- getThisAddress() - Method in class com.hazelcast.nio.NodeIOService
-  
- getThisAddress() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getThisAddress() - Method in interface com.hazelcast.spi.NodeEngine
- 
Get the address of this member. 
- getThreadGroup() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getThreadGroup() - Method in interface com.hazelcast.nio.IOService
-  
- getThreadGroup() - Method in class com.hazelcast.nio.NodeIOService
-  
- getThreadId() - Method in interface com.hazelcast.concurrent.lock.LockResource
-  
- getThreadId() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-  
- getThreadId() - Method in class com.hazelcast.map.impl.operation.MapOperation
-  
- getThreadId() - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-  
- getThreadId() - Method in class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-  
- getThreadId() - Method in class com.hazelcast.spi.impl.operationexecutor.classic.OperationThread
-  
- getThreadId() - Static method in class com.hazelcast.util.ThreadUtil
- 
Get the thread id 
- getThreadNamePrefix(String) - Method in class com.hazelcast.instance.HazelcastThreadGroup
- 
Gets the threadname prefix. 
- getThreadPoolNamePrefix(String) - Method in class com.hazelcast.instance.HazelcastThreadGroup
- 
Gets the threadpool prefix for a given poolname. 
- getThreadPrefix() - Method in interface com.hazelcast.nio.IOService
-  
- getThreadPrefix() - Method in class com.hazelcast.nio.NodeIOService
-  
- getThreads() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- getThreshold() - Method in class com.hazelcast.quorum.QuorumEvent
- 
Returns the predefined quorum threshold 
- getTime() - Method in class com.hazelcast.monitor.TimedMemberState
-  
- getTimedExpiryPolicyFactoryConfig() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
-  
- getTimeInMillis(long, TimeUnit) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- getTimeInMillis(long, TimeUnit) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-  
- getTimeInMillis(long, TimeUnit) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-  
- getTimeout(HazelcastInstance, String) - Static method in class com.hazelcast.hibernate.HazelcastTimestamper
-  
- getTimeout() - Method in class com.hazelcast.spi.impl.eventservice.impl.LocalEventDispatcher
-  
- getTimeout() - Method in interface com.hazelcast.util.executor.TimeoutRunnable
-  
- getTimeoutMilis() - Method in class com.hazelcast.transaction.impl.xa.XATransactionDTO
-  
- getTimeoutMillis() - Method in interface com.hazelcast.transaction.impl.Transaction
-  
- getTimeoutMillis() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-  
- getTimeoutMillis() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
-  
- getTimeoutMillis() - Method in class com.hazelcast.transaction.TransactionOptions
- 
Gets the timeout in milliseconds. 
- getTimestamp() - Method in class com.hazelcast.hibernate.local.Timestamp
-  
- getTimestamp() - Method in class com.hazelcast.hibernate.serialization.Value
-  
- getTimeToLiveSeconds() - Method in class com.hazelcast.config.MapConfig
- 
Returns the maximum number of seconds for each entry to stay in the map. 
- getTimeToLiveSeconds() - Method in class com.hazelcast.config.NearCacheConfig
- 
Gets the maximum number of seconds for each entry to stay in the near cache. 
- getTimeToLiveSeconds() - Method in class com.hazelcast.config.RingbufferConfig
- 
Gets the time to live in seconds. 
- getTimeUnit() - Method in enum com.hazelcast.client.config.ClientProperty
-  
- getTimeUnit() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
-  
- getTimeUnit() - Method in enum com.hazelcast.instance.GroupProperty
-  
- getTimeUnit() - Method in interface com.hazelcast.instance.HazelcastProperty
- 
- getTimeUnit() - Method in class com.hazelcast.spi.impl.eventservice.impl.LocalEventDispatcher
-  
- getTimeUnit() - Method in interface com.hazelcast.util.executor.TimeoutRunnable
-  
- getTopic() - Method in class com.hazelcast.client.console.ClientConsoleApp
-  
- getTopic(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getTopic(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getTopic() - Method in class com.hazelcast.console.ConsoleApp
-  
- getTopic(String) - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns the distributed topic instance with the specified name. 
- getTopic(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getTopic(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getTopic(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getTopic() - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
-  
- getTopicConfig(String) - Method in class com.hazelcast.config.Config
-  
- getTopicConfigs() - Method in class com.hazelcast.config.Config
-  
- getTopicOverloadPolicy() - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
- 
Gets the TopicOverloadPolicy for this reliable topic. 
- getTopicOverloadPolicy() - Method in class com.hazelcast.config.ReliableTopicConfig
- 
Gets the TopicOverloadPolicy for this reliable topic. 
- getTopologyChangedStrategy() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.AbstractMapReduceTask
-  
- getTopologyChangedStrategy() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForCustomMessageTask
-  
- getTopologyChangedStrategy() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForListMessageTask
-  
- getTopologyChangedStrategy() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMapMessageTask
-  
- getTopologyChangedStrategy() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMultiMapMessageTask
-  
- getTopologyChangedStrategy() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForSetMessageTask
-  
- getTopologyChangedStrategy() - Method in class com.hazelcast.config.JobTrackerConfig
- 
Gets how the map reduce framework will react on topology
 changes while executing a job. 
- getTopologyChangedStrategy() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-  
- getTotalBackupCount() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- getTotalBackupCount() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-  
- getTotalBackupCount() - Method in class com.hazelcast.config.CacheConfig
- 
Gets the total backup count (backupCount + asyncBackupCount) of the cache.
 
- getTotalBackupCount() - Method in class com.hazelcast.config.CollectionConfig
- 
Gets the total number of synchronous and asynchronous backups for this collection. 
- getTotalBackupCount() - Method in class com.hazelcast.config.MapConfig
- 
Returns the total number of backups: backupCount plus asyncBackupCount. 
- getTotalBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
- 
Gets the total number of backups (synchronous + asynchronous) for this MultiMap. 
- getTotalBackupCount() - Method in class com.hazelcast.config.QueueConfig
- 
Get the total number of backups: the backup count plus the asynchronous backup count. 
- getTotalBackupCount() - Method in class com.hazelcast.config.RingbufferConfig
- 
Returns the total number of backups: backupCount plus asyncBackupCount. 
- getTotalBackupCount() - Method in class com.hazelcast.config.SemaphoreConfig
- 
Returns the total number of backups (synchronous plus asynchronous);
 the returned value will always equal or bigger than 0. 
- getTotalBackupCount() - Method in class com.hazelcast.map.impl.MapContainer
-  
- getTotalConnections() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- getTotalExecutionLatency() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-  
- getTotalExecutionLatency() - Method in interface com.hazelcast.monitor.LocalExecutorStats
- 
Returns the total execution time of operations finished. 
- getTotalGetLatency() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getTotalGetLatency() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getTotalGetLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns the total latency of get operations. 
- getTotalMemory() - Method in class com.hazelcast.map.impl.eviction.EvictionCheckerImpl
-  
- getTotalMemory() - Method in interface com.hazelcast.util.MemoryInfoAccessor
- 
Returns total amount allocated memory in the Java virtual machine in bytes. 
- getTotalMemory() - Method in class com.hazelcast.util.RuntimeMemoryInfoAccessor
-  
- getTotalPhysical() - Method in class com.hazelcast.memory.DefaultMemoryStats
-  
- getTotalPhysical() - Method in interface com.hazelcast.memory.MemoryStats
- 
Returns total physical memory available in OS. 
- getTotalPhysical() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- getTotalPublishedEventCount() - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
-  
- getTotalPublishedEventCount() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
- 
Returns the total number of published events from this member 
- getTotalPublishLatency() - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
-  
- getTotalPublishLatency() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
- 
Returns the total latency of published wan events from this member by millisecond. 
- getTotalPutLatency() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getTotalPutLatency() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getTotalPutLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns the total latency of put operations. 
- getTotalRemoveLatency() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- getTotalRemoveLatency() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- getTotalRemoveLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
- 
Returns the total latency of remove operations. 
- getTotalStartLatency() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-  
- getTotalStartLatency() - Method in interface com.hazelcast.monitor.LocalExecutorStats
- 
Returns the total start latency of operations started. 
- getTotalStorageMemoryCost(K, R) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- getTotalWaitingOperationCount() - Method in class com.hazelcast.spi.impl.waitnotifyservice.impl.WaitNotifyServiceImpl
-  
- getTraceIdentifier() - Method in interface com.hazelcast.spi.TraceableOperation
- 
Returns the traceable identifier for this operation. 
- getTrackableJob(String) - Method in class com.hazelcast.client.proxy.ClientMapReduceProxy
-  
- getTrackableJob(String) - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-  
- getTrackableJob(String) - Method in interface com.hazelcast.mapreduce.JobTracker
- 
Returns an implementation of  TrackableJob, or null if the job id is not available
 or the job is already finished. 
- getTransaction() - Method in class com.hazelcast.client.proxy.txn.xa.XATransactionContextProxy
-  
- getTransaction() - Method in class com.hazelcast.client.txn.proxy.xa.XATransactionContextProxy
-  
- getTransaction() - Method in class com.hazelcast.transaction.client.BaseXATransactionRequest
-  
- getTransaction(TransactionContext) - Static method in class com.hazelcast.transaction.impl.xa.TransactionAccessor
-  
- getTransactionalList(String) - Method in interface com.hazelcast.jca.HazelcastConnection
-  
- getTransactionalList(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getTransactionalMap(String) - Method in interface com.hazelcast.jca.HazelcastConnection
-  
- getTransactionalMap(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getTransactionalMultiMap(String) - Method in interface com.hazelcast.jca.HazelcastConnection
-  
- getTransactionalMultiMap(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getTransactionalObject(String, String) - Method in class com.hazelcast.client.proxy.txn.TransactionContextProxy
-  
- getTransactionalObject(String, String) - Method in class com.hazelcast.client.proxy.txn.xa.XATransactionContextProxy
-  
- getTransactionalObject(String, String) - Method in class com.hazelcast.client.txn.proxy.xa.XATransactionContextProxy
-  
- getTransactionalObject(String, String) - Method in class com.hazelcast.client.txn.TransactionContextProxy
-  
- getTransactionalObject(String, String) - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
-  
- getTransactionalObject(String, String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
- 
Returns the transactional object instance with the specified name and service name. 
- getTransactionalQueue(String) - Method in interface com.hazelcast.jca.HazelcastConnection
-  
- getTransactionalQueue(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getTransactionalSet(String) - Method in interface com.hazelcast.jca.HazelcastConnection
-  
- getTransactionalSet(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getTransactionContext(String) - Method in interface com.hazelcast.client.ClientEndpoint
-  
- getTransactionContext(String) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- getTransactionContext() - Method in class com.hazelcast.client.proxy.txn.xa.XAResourceProxy
-  
- getTransactionContext() - Method in class com.hazelcast.client.txn.proxy.xa.XAResourceProxy
-  
- getTransactionContext() - Method in class com.hazelcast.jca.ManagedConnectionImpl
-  
- getTransactionContext() - Method in class com.hazelcast.transaction.client.BaseTransactionRequest
-  
- getTransactionContext() - Method in interface com.hazelcast.transaction.HazelcastXAResource
- 
Returns the TransactionContext associated with the current thread. 
- getTransactionContext() - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
-  
- getTransactionId() - Method in class com.hazelcast.collection.impl.collection.TxCollectionItem
-  
- getTransactionId() - Method in class com.hazelcast.collection.impl.txnqueue.TxQueueItem
-  
- getTransactionLog() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-  
- getTransactionManager() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getTransactionManager() - Method in class com.hazelcast.client.spi.ClientContext
-  
- getTransactionManagerService() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- getTransactionManagerService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getTransactionManagerService() - Method in interface com.hazelcast.spi.NodeEngine
- 
Gets the TransactionManagerService. 
- getTransactionRecords() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
-  
- getTransactionTimeout() - Method in class com.hazelcast.client.proxy.txn.xa.XAResourceProxy
-  
- getTransactionTimeout() - Method in class com.hazelcast.client.txn.proxy.xa.XAResourceProxy
-  
- getTransactionTimeout() - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
-  
- getTransactionType() - Method in class com.hazelcast.transaction.TransactionOptions
- 
- getTrustedInterfaces() - Method in class com.hazelcast.config.MulticastConfig
- 
Gets the trusted interfaces. 
- getTryCount() - Method in class com.hazelcast.cluster.impl.JoinRequest
-  
- getTryCount() - Method in class com.hazelcast.spi.InvocationBuilder
- 
Gets the try count; the number of times this operation can be retried. 
- getTryPauseMillis() - Method in class com.hazelcast.spi.InvocationBuilder
- 
Gets the pause time in milliseconds. 
- getTtl() - Method in interface com.hazelcast.core.EntryView
- 
Returns the last set time to live second. 
- getTtl() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-  
- getTtl() - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- getTtl() - Method in interface com.hazelcast.map.impl.record.Record
-  
- getTtl() - Method in class com.hazelcast.map.impl.record.RecordInfo
-  
- getTtl() - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- getTtl() - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
-  
- getTtl() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- getTtlMillis() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-  
- getTxContext() - Method in class com.hazelcast.jca.HazelcastTransactionImpl
-  
- getTxnId() - Method in class com.hazelcast.client.proxy.txn.TransactionContextProxy
-  
- getTxnId() - Method in class com.hazelcast.client.proxy.txn.xa.XATransactionContextProxy
-  
- getTxnId() - Method in class com.hazelcast.client.proxy.txn.xa.XATransactionProxy
-  
- getTxnId() - Method in class com.hazelcast.client.txn.proxy.xa.XATransactionContextProxy
-  
- getTxnId() - Method in class com.hazelcast.client.txn.proxy.xa.XATransactionProxy
-  
- getTxnId() - Method in class com.hazelcast.client.txn.TransactionContextProxy
-  
- getTxnId() - Method in class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
-  
- getTxnId() - Method in interface com.hazelcast.transaction.impl.Transaction
-  
- getTxnId() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-  
- getTxnId() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
-  
- getTxnId() - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
-  
- getTxnId() - Method in class com.hazelcast.transaction.impl.xa.XATransactionDTO
-  
- getTxnId() - Method in interface com.hazelcast.transaction.TransactionContext
- 
Gets the id that uniquely identifies the transaction. 
- getType() - Method in enum com.hazelcast.cache.impl.CacheEventType
-  
- getType() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- getType() - Method in class com.hazelcast.client.impl.client.GenericError
-  
- getType() - Method in class com.hazelcast.cluster.impl.MulticastJoiner
-  
- getType() - Method in class com.hazelcast.cluster.impl.TcpIpJoiner
-  
- getType() - Method in class com.hazelcast.cluster.impl.TcpIpJoinerOverAWS
-  
- getType() - Method in interface com.hazelcast.cluster.Joiner
-  
- getType() - Method in class com.hazelcast.config.PermissionConfig
-  
- getType(String) - Static method in enum com.hazelcast.config.PermissionConfig.PermissionType
-  
- getType() - Method in class com.hazelcast.config.QuorumConfig
-  
- getType() - Method in enum com.hazelcast.core.EntryEventType
- 
Returns the event type. 
- getType() - Method in enum com.hazelcast.core.ItemEventType
-  
- getType() - Method in class com.hazelcast.internal.ascii.AbstractTextCommand
-  
- getType() - Method in interface com.hazelcast.internal.ascii.TextCommand
-  
- getType() - Method in class com.hazelcast.internal.management.request.ChangeClusterStateRequest
-  
- getType() - Method in class com.hazelcast.internal.management.request.ChangeWanStateRequest
-  
- getType() - Method in class com.hazelcast.internal.management.request.ClusterPropsRequest
-  
- getType() - Method in class com.hazelcast.internal.management.request.ConsoleCommandRequest
-  
- getType() - Method in interface com.hazelcast.internal.management.request.ConsoleRequest
-  
- getType() - Method in class com.hazelcast.internal.management.request.ExecuteScriptRequest
-  
- getType() - Method in class com.hazelcast.internal.management.request.ForceStartNodeRequest
-  
- getType() - Method in class com.hazelcast.internal.management.request.GetClusterStateRequest
-  
- getType() - Method in class com.hazelcast.internal.management.request.GetLogsRequest
- 
Deprecated. 
- getType() - Method in class com.hazelcast.internal.management.request.GetMapEntryRequest
-  
- getType() - Method in class com.hazelcast.internal.management.request.GetMemberSystemPropertiesRequest
-  
- getType() - Method in class com.hazelcast.internal.management.request.GetSystemWarningsRequest
- 
Deprecated. 
- getType() - Method in class com.hazelcast.internal.management.request.MapConfigRequest
-  
- getType() - Method in class com.hazelcast.internal.management.request.MemberConfigRequest
-  
- getType() - Method in class com.hazelcast.internal.management.request.RunGcRequest
-  
- getType() - Method in class com.hazelcast.internal.management.request.ShutdownClusterRequest
-  
- getType() - Method in class com.hazelcast.internal.management.request.ShutdownMemberRequest
-  
- getType() - Method in class com.hazelcast.internal.management.request.ThreadDumpRequest
-  
- getType() - Method in class com.hazelcast.internal.serialization.impl.FieldDefinitionImpl
-  
- getType() - Method in class com.hazelcast.internal.serialization.impl.HeapData
-  
- getType() - Method in interface com.hazelcast.nio.Connection
- 
- getType() - Method in interface com.hazelcast.nio.serialization.Data
- 
Returns serialization type of binary form. 
- getType() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
-  
- getType() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- getTypeClass() - Method in class com.hazelcast.config.SerializerConfig
- 
Gets the type of the class that will be serialized via this implementation. 
- getTypeClassName() - Method in class com.hazelcast.config.SerializerConfig
- 
Gets the name of the class that will be serialized via this implementation. 
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ArrayListStreamSerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.BooleanArraySerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.BooleanSerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.ByteSerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.CharArraySerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.CharSerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.DoubleArraySerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.DoubleSerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.FloatArraySerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.FloatSerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.IntegerArraySerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.IntegerSerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.LongArraySerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.LongSerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.NullSerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.ShortArraySerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.ShortSerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.StringArraySerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.StringSerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.TheByteArraySerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.BigDecimalSerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.BigIntegerSerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.ClassSerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.DateSerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.EnumSerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.ExternalizableSerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.JavaSerializer
-  
- getTypeId() - Method in class com.hazelcast.internal.serialization.impl.LinkedListStreamSerializer
-  
- getTypeId() - Method in interface com.hazelcast.nio.serialization.Serializer
-  
- getTypeSize() - Method in enum com.hazelcast.nio.serialization.FieldType
-  
- getUnit() - Method in class com.hazelcast.memory.MemorySize
- 
Returns unit of memory size 
- getUnknownCollectionCount() - Method in class com.hazelcast.memory.DefaultGarbageCollectorStats
-  
- getUnknownCollectionCount() - Method in interface com.hazelcast.memory.GarbageCollectorStats
- 
Returns collection count which cannot be identified as major or minor. 
- getUnknownCollectionCount() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-  
- getUnknownCollectionTime() - Method in class com.hazelcast.memory.DefaultGarbageCollectorStats
-  
- getUnknownCollectionTime() - Method in interface com.hazelcast.memory.GarbageCollectorStats
- 
Returns total collection time which cannot be identified as major or minor. 
- getUnknownCollectionTime() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-  
- getUpdateInterval() - Method in class com.hazelcast.config.ManagementCenterConfig
- 
Gets the time frequency (in seconds) for which Management Center will take
 information from the Hazelcast cluster. 
- getUpdateTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-  
- getUptime() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- getURI() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- getURI() - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
-  
- getUriString() - Method in class com.hazelcast.config.CacheConfig
- 
Gets the URI string which is the global identifier for this  ICache. 
- getUrl() - Method in class com.hazelcast.config.ManagementCenterConfig
- 
Gets the URL where management center will work. 
- getUsage() - Method in class com.hazelcast.config.LoginModuleConfig
-  
- getUsedHeap() - Method in class com.hazelcast.memory.DefaultMemoryStats
-  
- getUsedHeap() - Method in interface com.hazelcast.memory.MemoryStats
- 
Returns the amount of used memory in the JVM in bytes. 
- getUsedHeap() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- getUsedHeapSize(String) - Method in class com.hazelcast.map.impl.eviction.EvictionCheckerImpl
-  
- getUsedNativeMemory() - Method in class com.hazelcast.memory.DefaultMemoryStats
-  
- getUsedNativeMemory() - Method in interface com.hazelcast.memory.MemoryStats
- 
Returns the amount of used native memory in current HazelcastInstance in bytes. 
- getUsedNativeMemory() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- getUserContext() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getUserContext() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getUserContext() - Method in class com.hazelcast.config.Config
-  
- getUserContext() - Method in interface com.hazelcast.core.HazelcastInstance
- 
Returns a ConcurrentMap that can be used to add user-context to the HazelcastInstance. 
- getUserContext() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getUserContext() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getUserContext() - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getUsername() - Method in class com.hazelcast.security.UsernamePasswordCredentials
- 
Gets the user name. 
- getUuid() - Method in class com.hazelcast.client.ClientEvent
-  
- getUuid() - Method in class com.hazelcast.client.impl.client.ClientPrincipal
-  
- getUuid() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- getUuid() - Method in class com.hazelcast.client.impl.ClientImpl
-  
- getUuid() - Method in class com.hazelcast.cluster.client.MemberAttributeChange
-  
- getUuid() - Method in class com.hazelcast.cluster.impl.JoinMessage
-  
- getUuid() - Method in class com.hazelcast.cluster.MemberInfo
-  
- getUuid() - Method in interface com.hazelcast.core.Client
- 
Returns a unique uuid for this client. 
- getUuid() - Method in interface com.hazelcast.core.Endpoint
- 
Returns the unique uuid for this endpoint. 
- getUuid() - Method in interface com.hazelcast.core.Member
- 
Returns the UUID of this member. 
- getUuid() - Method in class com.hazelcast.instance.AbstractMember
-  
- getUuid() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-  
- getUuid() - Method in class com.hazelcast.spi.impl.PortableCachePartitionLostEvent
-  
- getUuid() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-  
- getUuid() - Method in class com.hazelcast.spi.impl.PortableItemEvent
-  
- getUuid() - Method in class com.hazelcast.spi.impl.PortableMapPartitionLostEvent
-  
- getUuid() - Method in class com.hazelcast.topic.impl.client.PortableMessage
-  
- getValidationTimeoutSeconds() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
- 
Returns configured validation timeout for hot-restart process. 
- getValue() - Method in interface com.hazelcast.cache.CacheEntryView
- 
Gets the value of the cache entry. 
- getValue() - Method in class com.hazelcast.cache.impl.CacheEntry
-  
- getValue() - Method in class com.hazelcast.cache.impl.CacheEntryEventImpl
-  
- getValue() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-  
- getValue() - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
-  
- getValue() - Method in class com.hazelcast.cache.impl.merge.entry.LazyCacheEntryView
-  
- getValue() - Method in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-  
- getValue() - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheRecord
- 
- getValue() - Method in class com.hazelcast.cache.impl.record.CacheDataRecord
-  
- getValue() - Method in class com.hazelcast.cache.impl.record.CacheObjectRecord
-  
- getValue() - Method in interface com.hazelcast.cache.impl.record.CacheRecord
- 
- getValue() - Method in class com.hazelcast.cluster.client.MemberAttributeChange
-  
- getValue(int) - Static method in enum com.hazelcast.cluster.MemberAttributeOperationType
-  
- getValue() - Method in class com.hazelcast.collection.impl.collection.CollectionItem
-  
- getValue() - Method in class com.hazelcast.core.EntryEvent
- 
Returns the value of the entry event. 
- getValue() - Method in interface com.hazelcast.core.EntryView
- 
Returns the value of the entry. 
- getValue() - Method in class com.hazelcast.core.MemberAttributeEvent
- 
Returns the value for this MemberAttributeEvent. 
- getValue() - Method in class com.hazelcast.hibernate.serialization.Expirable
-  
- getValue(long) - Method in class com.hazelcast.hibernate.serialization.Expirable
-  
- getValue() - Method in class com.hazelcast.hibernate.serialization.ExpiryMarker
-  
- getValue(long) - Method in class com.hazelcast.hibernate.serialization.ExpiryMarker
-  
- getValue() - Method in class com.hazelcast.hibernate.serialization.Value
-  
- getValue(long) - Method in class com.hazelcast.hibernate.serialization.Value
-  
- getValue() - Method in class com.hazelcast.internal.ascii.memcache.IncrementCommand
-  
- getValue() - Method in class com.hazelcast.internal.ascii.memcache.MemcacheEntry
-  
- getValue() - Method in class com.hazelcast.internal.ascii.memcache.SetCommand
-  
- getValue() - Method in class com.hazelcast.internal.ascii.rest.RestValue
-  
- getValue() - Method in enum com.hazelcast.internal.ascii.TextCommandConstants.TextCommandType
-  
- getValue() - Method in class com.hazelcast.map.impl.DataAwareEntryEvent
-  
- getValue() - Method in class com.hazelcast.map.impl.LazyMapEntry
-  
- getValue() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntry
-  
- getValue() - Method in class com.hazelcast.map.impl.nearcache.NearCacheRecord
-  
- getValue() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-  
- getValue() - Method in class com.hazelcast.map.impl.query.QueryResultRow
-  
- getValue() - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- getValue() - Method in interface com.hazelcast.map.impl.querycache.event.QueryCacheEventData
-  
- getValue() - Method in interface com.hazelcast.map.impl.record.Record
-  
- getValue() - Method in class com.hazelcast.map.impl.record.RecordReplicationInfo
-  
- getValue() - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- getValue() - Method in class com.hazelcast.memory.MemorySize
- 
Returns value of memory size in its original unit. 
- getValue() - Method in class com.hazelcast.query.impl.CachedQueryEntry
-  
- getValue() - Method in class com.hazelcast.query.impl.QueryableEntry
-  
- getValue() - Method in class com.hazelcast.query.impl.QueryEntry
-  
- getValue() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-  
- getValue() - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
-  
- getValue() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- getValue() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-  
- getValue() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.NormalResponse
- 
Returns the object value of the operation. 
- getValue() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-  
- getValue() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.EntryIterator
-  
- getValue() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.EntryIterator
-  
- getValue() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap.SimpleEntry
-  
- getValue() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
-  
- getValue(String) - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- getValue() - Method in class com.hazelcast.web.LocalCacheEntry
- 
Gets value. 
- getValueCollectionType() - Method in class com.hazelcast.config.MultiMapConfig
- 
Gets the collection type for the values of this MultiMap. 
- getValueCollectionType(MultiMapContainer) - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-  
- getValueData() - Method in class com.hazelcast.map.impl.LazyMapEntry
-  
- getValueData() - Method in class com.hazelcast.query.impl.CachedQueryEntry
-  
- getValueData() - Method in class com.hazelcast.query.impl.QueryableEntry
-  
- getValueData() - Method in class com.hazelcast.query.impl.QueryEntry
-  
- getValueInternal() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-  
- getValueNames() - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- getValueOrCachedValue(Record, SerializationService) - Static method in class com.hazelcast.map.impl.record.Records
- 
Return cached value where appropriate, otherwise return the actual value. 
- getValues() - Method in class com.hazelcast.map.impl.MapValueCollection
-  
- getValues() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapValueCollection
-  
- getValueType() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
-  
- getValueType() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Gets the value type for this  ICache. 
- getVersion() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
- 
Returns the version field value. 
- getVersion() - Method in interface com.hazelcast.concurrent.lock.LockResource
-  
- getVersion(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- getVersion() - Method in interface com.hazelcast.core.EntryView
- 
Returns the version of the entry 
- getVersion() - Method in class com.hazelcast.hibernate.local.Invalidation
-  
- getVersion() - Method in class com.hazelcast.hibernate.serialization.Expirable
-  
- getVersion() - Method in class com.hazelcast.instance.BuildInfo
-  
- getVersion() - Method in class com.hazelcast.internal.management.ManagementCenterIdentifier
-  
- getVersion() - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- getVersion() - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-  
- getVersion() - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- getVersion() - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableWriter
-  
- getVersion() - Method in interface com.hazelcast.internal.serialization.PortableContext
-  
- getVersion() - Method in interface com.hazelcast.internal.serialization.SerializationService
-  
- getVersion() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- getVersion() - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- getVersion() - Method in interface com.hazelcast.map.impl.record.Record
-  
- getVersion() - Method in class com.hazelcast.map.impl.record.RecordInfo
-  
- getVersion() - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- getVersion() - Method in interface com.hazelcast.map.impl.tx.MapTxnOperation
-  
- getVersion() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-  
- getVersion() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-  
- getVersion() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-  
- getVersion() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
- 
Returns the version. 
- getVersion() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-  
- getVersion() - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- getVersion() - Method in class com.hazelcast.partition.PartitionRuntimeState
-  
- getVersion() - Method in class com.hazelcast.replicatedmap.impl.operation.VersionResponsePair
-  
- getVersion() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-  
- getVersion() - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
-  
- getVersion() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- getVersion() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- getVersionAsInt(String) - Static method in class com.hazelcast.internal.management.ManagementCenterIdentifier
-  
- getVersionString() - Method in class com.hazelcast.internal.management.ManagementCenterIdentifier
-  
- getWaitingRequests() - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- getWaitKey() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
-  
- getWaitKey() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
-  
- getWaitKey() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPeekOperation
-  
- getWaitKey() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferOperation
-  
- getWaitKey() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollOperation
-  
- getWaitKey() - Method in class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
-  
- getWaitKey() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
-  
- getWaitKey() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
-  
- getWaitKey() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
-  
- getWaitKey() - Method in class com.hazelcast.map.impl.operation.ContainsKeyOperation
-  
- getWaitKey() - Method in class com.hazelcast.map.impl.operation.GetEntryViewOperation
-  
- getWaitKey() - Method in class com.hazelcast.map.impl.operation.GetOperation
-  
- getWaitKey() - Method in class com.hazelcast.map.impl.operation.LockAwareOperation
-  
- getWaitKey() - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-  
- getWaitKey() - Method in class com.hazelcast.multimap.impl.operations.CountOperation
-  
- getWaitKey() - Method in class com.hazelcast.multimap.impl.operations.GetAllOperation
-  
- getWaitKey() - Method in class com.hazelcast.multimap.impl.operations.MultiMapBackupAwareOperation
-  
- getWaitKey() - Method in class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
-  
- getWaitKey() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadManyOperation
-  
- getWaitKey() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadOneOperation
-  
- getWaitKey() - Method in interface com.hazelcast.spi.WaitSupport
-  
- getWaitNotifyService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getWaitNotifyService() - Method in interface com.hazelcast.spi.NodeEngine
- 
Gets the WaitNotifyService. 
- getWaitTimeout() - Method in class com.hazelcast.spi.Operation
-  
- getWaitTimeout() - Method in interface com.hazelcast.spi.WaitSupport
-  
- getWanMergePolicy() - Method in class com.hazelcast.map.impl.MapContainer
-  
- getWanReplicationConfig(String) - Method in class com.hazelcast.config.Config
-  
- getWanReplicationConfigs() - Method in class com.hazelcast.config.Config
-  
- getWanReplicationPublisher() - Method in class com.hazelcast.map.impl.MapContainer
-  
- getWanReplicationPublisher(String) - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
-  
- getWanReplicationPublisher(String) - Method in interface com.hazelcast.wan.WanReplicationService
- 
- getWanReplicationRef() - Method in class com.hazelcast.config.CacheConfig
-  
- getWanReplicationRef() - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- getWanReplicationRef() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Gets the WAN target replication reference. 
- getWanReplicationRef() - Method in class com.hazelcast.config.MapConfig
- 
Gets the Wan target replication reference. 
- getWanReplicationRef() - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- getWanReplicationService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- getWanReplicationService() - Method in interface com.hazelcast.spi.NodeEngine
- 
Gets the WanReplicationService. 
- getWorkQueueSize() - Method in class com.hazelcast.util.executor.StripedExecutor
- 
Returns the total number of tasks pending to be executed. 
- getWriteBatchSize() - Method in class com.hazelcast.config.MapStoreConfig
- 
Returns the number of operations to be included in each batch processing round. 
- getWriteBehindQueue() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-  
- getWriteBehindQueueItemCounter() - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- getWriteDelaySeconds() - Method in class com.hazelcast.config.MapStoreConfig
- 
Returns the number of seconds to delay the store writes. 
- getWriteHandler() - Method in class com.hazelcast.internal.ascii.AbstractTextCommand
-  
- getWriteHandler() - Method in interface com.hazelcast.internal.ascii.TextCommand
-  
- getWriteHandler() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingSocketWriter
-  
- getWriteHandler() - Method in interface com.hazelcast.nio.tcp.SocketWriter
- 
- getWriteHandler() - Method in class com.hazelcast.nio.tcp.spinning.SpinningSocketWriter
-  
- getXAResource() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- getXAResource() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- getXaResource() - Method in class com.hazelcast.client.proxy.txn.TransactionContextProxy
-  
- getXaResource() - Method in class com.hazelcast.client.proxy.txn.xa.XATransactionContextProxy
-  
- getXaResource() - Method in class com.hazelcast.client.txn.proxy.xa.XATransactionContextProxy
-  
- getXaResource() - Method in class com.hazelcast.client.txn.TransactionContextProxy
-  
- getXAResource() - Method in interface com.hazelcast.core.HazelcastInstance
- 
Gets xaResource which will participate in XATransaction. 
- getXAResource() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- getXAResource() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- getXAResource() - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- getXAResource() - Method in class com.hazelcast.jca.ManagedConnectionImpl
-  
- getXaResource() - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
-  
- getXaResource() - Method in interface com.hazelcast.transaction.TransactionContext
- 
Deprecated.
since 3.5 please use HazelcastInstance.getXAResource() 
 
- getXAResources(ActivationSpec[]) - Method in class com.hazelcast.jca.ResourceAdapterImpl
-  
- getXid() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
-  
- getXid() - Method in class com.hazelcast.transaction.impl.xa.XATransactionDTO
-  
- getXmlType() - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
-  
- getXmlType() - Method in class com.hazelcast.config.AbstractConfigBuilder
-  
- getXmlType() - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-  
- getXmlType() - Method in class com.hazelcast.config.XmlConfigBuilder
-  
- getZonesSet() - Method in class com.hazelcast.jclouds.ComputeServiceBuilder
-  
- gigaBytes() - Method in class com.hazelcast.memory.MemorySize
- 
Returns value of memory size in giga-bytes. 
- globalPartitioningStrategy - Variable in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- GlobalSerializerConfig - Class in com.hazelcast.config
- 
Contains the configuration for global serializer. 
- GlobalSerializerConfig() - Constructor for class com.hazelcast.config.GlobalSerializerConfig
-  
- greaterEqual(Comparable) - Method in class com.hazelcast.query.EntryObject
-  
- greaterEqual(String, Comparable) - Static method in class com.hazelcast.query.Predicates
-  
- GREATERLESS_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
-  
- GreaterLessPredicate - Class in com.hazelcast.query.impl.predicates
- 
Greater Less Predicate 
- GreaterLessPredicate() - Constructor for class com.hazelcast.query.impl.predicates.GreaterLessPredicate
-  
- GreaterLessPredicate(String, Comparable, boolean, boolean) - Constructor for class com.hazelcast.query.impl.predicates.GreaterLessPredicate
-  
- greaterThan(Comparable) - Method in class com.hazelcast.query.EntryObject
-  
- greaterThan(String, Comparable) - Static method in class com.hazelcast.query.Predicates
-  
- GROUP - Static variable in class com.hazelcast.jclouds.JCloudsProperties
- 
Property used to define group keys for node filtering 
- GroupConfig - Class in com.hazelcast.config
- 
Contains the configuration for Hazelcast groups. 
- GroupConfig() - Constructor for class com.hazelcast.config.GroupConfig
- 
Creates a GroupConfig with default group-name and group-password. 
- GroupConfig(String) - Constructor for class com.hazelcast.config.GroupConfig
- 
Creates a GroupConfig with the given group-name and default group-password 
- GroupConfig(String, String) - Constructor for class com.hazelcast.config.GroupConfig
- 
Creates a GroupConfig with the given group-name and group-password 
- GroupMismatchOperation - Class in com.hazelcast.cluster.impl.operations
-  
- GroupMismatchOperation() - Constructor for class com.hazelcast.cluster.impl.operations.GroupMismatchOperation
-  
- GroupProperties - Class in com.hazelcast.instance
- 
- GroupProperties(Config) - Constructor for class com.hazelcast.instance.GroupProperties
- 
Creates a container with configured Hazelcast properties. 
- groupProperties - Variable in class com.hazelcast.instance.Node
-  
- GroupProperty - Enum in com.hazelcast.instance
- 
Defines the name and default value for Hazelcast properties. 
- IAMRoleCredentialSupplierBuilder - Class in com.hazelcast.jclouds
- 
Build SessionCredentials for JClouds Compute Service API
 with IAM Role. 
- IAMRoleCredentialSupplierBuilder() - Constructor for class com.hazelcast.jclouds.IAMRoleCredentialSupplierBuilder
-  
- IAtomicLong - Interface in com.hazelcast.core
- 
- IAtomicReference<E> - Interface in com.hazelcast.core
- 
- ICache<K,V> - Interface in com.hazelcast.cache
- 
This  ICache interface is the  Cache extension offered by
 Hazelcast JCache. 
 In addition to the standard set of JCache methods defined in the JSR 107 specification, Hazelcast provides
 additional operations to support a broader range of programing styles. 
- ICacheEvent - Interface in com.hazelcast.cache.impl.event
- 
Cache events common contract. 
- ICacheInternal<K,V> - Interface in com.hazelcast.cache.impl
- 
Internal API for  ICache implementations. 
- ICacheRecordStore - Interface in com.hazelcast.cache.impl
- 
ICacheRecordStore is the core contract providing internal functionality to
  ICache implementations on partition scope. 
- ICacheService - Interface in com.hazelcast.cache.impl
-  
- ICollection<E> - Interface in com.hazelcast.core
- 
Concurrent, distributed, partitioned, listenable collection. 
- ICompletableFuture<V> - Interface in com.hazelcast.core
- 
A Future where one can asynchronously listen on completion. 
- IConcurrentMap<K,V> - Interface in com.hazelcast.util
- 
- ICondition - Interface in com.hazelcast.core
- 
- ICountDownLatch - Interface in com.hazelcast.core
- 
- ICredentialsFactory - Interface in com.hazelcast.security
- 
ICredentialsFactory is used to create  Credentials objects to be used
 during node authentication before connection is accepted by the master node. 
- ID - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-  
- ID - Static variable in class com.hazelcast.client.impl.ClientDataSerializerHook
- 
ClientDataSerializable Factory ID 
- id - Variable in class com.hazelcast.internal.management.dto.SlowOperationInvocationDTO
-  
- ID - Static variable in class com.hazelcast.nio.Address
-  
- ID - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
-  
- id() - Method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
-  
- IdentifiedDataSerializable - Interface in com.hazelcast.nio.serialization
- 
IdentifiedDataSerializable is an extension to  DataSerializable
 to avoid reflection during de-serialization. 
- IDENTITY - Static variable in class com.hazelcast.jclouds.JCloudsProperties
- 
Unique credential identity specific to users cloud account 
- IDENTITY_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
-  
- IdGenerator - Interface in com.hazelcast.core
- 
The IdGenerator is responsible for creating unique ids (a long) in a cluster.
 
- IdGeneratorImpl - Class in com.hazelcast.concurrent.idgen
- 
Generates blocks with the help of an  IAtomicLong
 For each block, id generation is simply a volatile increment 
- IdGeneratorImpl(IAtomicLong) - Constructor for class com.hazelcast.concurrent.idgen.IdGeneratorImpl
-  
- IdGeneratorProxy - Class in com.hazelcast.concurrent.idgen
-  
- IdGeneratorProxy(IAtomicLong, String, NodeEngine, IdGeneratorService) - Constructor for class com.hazelcast.concurrent.idgen.IdGeneratorProxy
-  
- IdGeneratorService - Class in com.hazelcast.concurrent.idgen
-  
- IdGeneratorService(NodeEngine) - Constructor for class com.hazelcast.concurrent.idgen.IdGeneratorService
-  
- idle(long) - Method in class com.hazelcast.util.concurrent.BackoffIdleStrategy
- 
Perform current idle strategy's step n. 
- idle(long) - Method in class com.hazelcast.util.concurrent.BusySpinIdleStrategy
-  
- idle(long) - Method in interface com.hazelcast.util.concurrent.IdleStrategy
- 
Perform current idle strategy's step n. 
- idle(long) - Method in class com.hazelcast.util.concurrent.NoOpIdleStrategy
-  
- IdleStrategy - Interface in com.hazelcast.util.concurrent
- 
Idle strategy for use by threads when then they don't have work to do. 
- IExecutorService - Interface in com.hazelcast.core
- 
- IFunction<T,R> - Interface in com.hazelcast.core
- 
Represents a function that accepts one argument and produces a result. 
- ignore(Throwable) - Static method in class com.hazelcast.util.EmptyStatement
- 
Does totally nothing. 
- IGNORE_ALL_EXCEPT_LOG_MEMBER_LEFT - Static variable in class com.hazelcast.util.FutureUtil
- 
Ignores all exceptions but still logs  MemberLeftException per future and just tries
 to finish all of the given ones. 
- IGNORE_ALL_EXCEPTIONS - Static variable in class com.hazelcast.util.FutureUtil
- 
Ignores all exceptions 
- IGNORE_COMPLETION - Static variable in interface com.hazelcast.cache.impl.operation.MutableOperation
- 
Completion Id to be ignored. 
- IHazelcastInstanceLoader - Interface in com.hazelcast.hibernate.instance
- 
Factory interface to build Hazelcast instances and configure them depending
 on configuration. 
- ilike(String, String) - Static method in class com.hazelcast.query.Predicates
-  
- ILIKE_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
-  
- ILikePredicate - Class in com.hazelcast.query.impl.predicates
- 
Ilike Predicate 
- ILikePredicate() - Constructor for class com.hazelcast.query.impl.predicates.ILikePredicate
-  
- ILikePredicate(String, String) - Constructor for class com.hazelcast.query.impl.predicates.ILikePredicate
-  
- IList<E> - Interface in com.hazelcast.core
- 
Concurrent, distributed implementation of  List
 The Hazelcast IList is not a partitioned data-structure. 
- ILLEGAL_ACCESS_ERROR - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- ILLEGAL_ACCESS_EXCEPTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- ILLEGAL_ARGUMENT - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- ILLEGAL_MONITOR_STATE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- ILLEGAL_STATE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- ILLEGAL_THREAD_STATE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- ILock - Interface in com.hazelcast.core
- 
Distributed implementation of  Lock. 
- ILogger - Interface in com.hazelcast.logging
- 
The Hazelcast logging interface. 
- IMap<K,V> - Interface in com.hazelcast.core
- 
Concurrent, distributed, observable and queryable map. 
- IMapEvent - Interface in com.hazelcast.core
- 
Map events common contract. 
- IMapRegionCache - Class in com.hazelcast.hibernate.distributed
- 
A  RegionCache implementation based on the underlying IMap 
- IMapRegionCache(String, HazelcastInstance, Properties, CacheDataDescription) - Constructor for class com.hazelcast.hibernate.distributed.IMapRegionCache
-  
- implementation - Variable in class com.hazelcast.config.ListenerConfig
-  
- implementation - Variable in class com.hazelcast.config.PredicateConfig
-  
- implementation - Variable in class com.hazelcast.config.SecurityInterceptorConfig
-  
- implies(Permission) - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
-  
- implies(Permission) - Method in class com.hazelcast.security.permission.AllPermissions
-  
- implies(Permission) - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
-  
- implies(Permission) - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
-  
- implies(Permission) - Method in class com.hazelcast.security.permission.InstancePermission
-  
- implies(Permission) - Method in class com.hazelcast.security.permission.TransactionPermission
-  
- in(Comparable...) - Method in class com.hazelcast.query.EntryObject
-  
- in(String, Comparable...) - Static method in class com.hazelcast.query.Predicates
-  
- IN_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
-  
- inc() - Method in interface com.hazelcast.util.counters.Counter
- 
Increments the counter by one. 
- inc(long) - Method in interface com.hazelcast.util.counters.Counter
- 
Increments (or decrements) the counter by the given amount. 
- inc() - Method in class com.hazelcast.util.counters.MwCounter
-  
- inc(long) - Method in class com.hazelcast.util.counters.MwCounter
-  
- includeValue - Variable in class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-  
- includeValue - Variable in class com.hazelcast.map.impl.EntryEventFilter
-  
- increaseCacheEntryListenerCount() - Method in class com.hazelcast.cache.impl.CacheContext
-  
- increaseCacheEvictions() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
- 
Increases the counter by `1`. 
- increaseCacheEvictions(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
- 
Increases the counter by the number specified. 
- increaseCacheExpiries() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
- 
Increases the counter by `1`. 
- increaseCacheExpiries(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
- 
Increases the counter by the number specified. 
- increaseCacheHits() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
- 
Increases the counter by `1`. 
- increaseCacheHits(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
- 
Increases the counter by the number specified. 
- increaseCacheMisses() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
- 
Increases the counter by `1`. 
- increaseCacheMisses(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
- 
Increases the counter by the number specified. 
- increaseCachePuts() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
- 
Increases the counter by `1`. 
- increaseCachePuts(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
- 
Increases the counter by the number specified. 
- increaseCacheRemovals() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
- 
Increases the counter by `1`. 
- increaseCacheRemovals(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
- 
Increases the counter by the number specified. 
- increaseEntryCount() - Method in class com.hazelcast.cache.impl.CacheContext
-  
- increaseEntryCount(long) - Method in class com.hazelcast.cache.impl.CacheContext
-  
- increaseEntryCount() - Method in class com.hazelcast.cache.impl.CacheEntryCountResolver
-  
- increaseEntryCount(long) - Method in class com.hazelcast.cache.impl.CacheEntryCountResolver
-  
- increaseInvalidationListenerCount() - Method in class com.hazelcast.cache.impl.CacheContext
-  
- increaseInvalidationListenerCount() - Method in class com.hazelcast.map.impl.MapContainer
-  
- incrementAccessHit() - Method in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-  
- incrementAccessHit() - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheRecord
- 
Increases the access hit count of this  Evictable as  1. 
- incrementAccessHit() - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-  
- incrementAccessHit() - Method in interface com.hazelcast.cache.impl.record.CacheRecord
- 
Increases the access hit count of this  Evictable as  1. 
- incrementAndGet() - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-  
- incrementAndGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- incrementAndGet() - Method in interface com.hazelcast.core.IAtomicLong
- 
Atomically increments the current value by one. 
- incrementAndGet() - Method in class com.hazelcast.jmx.AtomicLongMBean
-  
- incrementBackupEntryCount(long) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
-  
- incrementBackupEntryMemoryCost(long) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
-  
- IncrementCommand - Class in com.hazelcast.internal.ascii.memcache
-  
- IncrementCommand(TextCommandConstants.TextCommandType, String, int, boolean) - Constructor for class com.hazelcast.internal.ascii.memcache.IncrementCommand
-  
- IncrementCommandParser - Class in com.hazelcast.internal.ascii.memcache
-  
- IncrementCommandParser(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.internal.ascii.memcache.IncrementCommandParser
-  
- IncrementCommandProcessor - Class in com.hazelcast.internal.ascii.memcache
-  
- IncrementCommandProcessor(TextCommandServiceImpl) - Constructor for class com.hazelcast.internal.ascii.memcache.IncrementCommandProcessor
-  
- incrementDecrHitCount() - Method in interface com.hazelcast.internal.ascii.TextCommandService
-  
- incrementDecrHitCount() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- incrementDecrMissCount() - Method in interface com.hazelcast.internal.ascii.TextCommandService
-  
- incrementDecrMissCount() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- incrementDeleteHitCount(int) - Method in interface com.hazelcast.internal.ascii.TextCommandService
-  
- incrementDeleteHitCount(int) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- incrementDeleteMissCount() - Method in interface com.hazelcast.internal.ascii.TextCommandService
-  
- incrementDeleteMissCount() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- incrementDirtyEntryCount(long) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
-  
- incrementEmptyPolls() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- incrementGetHitCount() - Method in interface com.hazelcast.internal.ascii.TextCommandService
-  
- incrementGetHitCount() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- incrementGetMissCount() - Method in interface com.hazelcast.internal.ascii.TextCommandService
-  
- incrementGetMissCount() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- incrementGets(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- incrementGets(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- incrementHeapCost(long) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
-  
- incrementHit() - Method in class com.hazelcast.multimap.impl.MultiMapValue
-  
- incrementHits(long) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
-  
- incrementHits() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-  
- incrementIncHitCount() - Method in interface com.hazelcast.internal.ascii.TextCommandService
-  
- incrementIncHitCount() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- incrementIncMissCount() - Method in interface com.hazelcast.internal.ascii.TextCommandService
-  
- incrementIncMissCount() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- incrementLockedEntryCount(long) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
-  
- incrementMisses() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-  
- incrementOffers() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- incrementOperationStats(long, LocalMapStatsImpl, String, Operation) - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- incrementOtherOperations() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- incrementOtherOperations() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- incrementOtherOperations() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- incrementOwnedEntryCount(long) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
-  
- incrementOwnedEntryCount() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-  
- incrementOwnedEntryMemoryCost(long) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
-  
- incrementOwnedEntryMemoryCost(long) - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-  
- incrementPartitionReplicaVersions(int, int) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- incrementPartitionReplicaVersions(int, int) - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- incrementPendingPacketCount() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- incrementPolls() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- incrementPublishedEventCount(long) - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
-  
- incrementPublishes() - Method in class com.hazelcast.monitor.impl.LocalTopicStatsImpl
-  
- incrementPublishes(String) - Method in class com.hazelcast.topic.impl.TopicService
-  
- incrementPuts(long, long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- incrementPuts(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- incrementPuts(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- incrementReceivedEvents() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- incrementReceivedEvents() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- incrementReceivedEvents() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- incrementReceivedMessages(String) - Method in class com.hazelcast.topic.impl.TopicService
-  
- incrementReceives() - Method in class com.hazelcast.monitor.impl.LocalTopicStatsImpl
-  
- incrementRejectedOffers() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- incrementRemoves(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- incrementRemoves(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- incrementSetCount() - Method in interface com.hazelcast.internal.ascii.TextCommandService
-  
- incrementSetCount() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- incrementTextConnections() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- incrementTouchCount() - Method in interface com.hazelcast.internal.ascii.TextCommandService
-  
- incrementTouchCount() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- incrementVersion() - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
-  
- index - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-  
- index() - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- index(int) - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- Index - Interface in com.hazelcast.query.impl
- 
This interface contains the methods related to index of Query. 
- INDEX_OF - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- INDEX_OUT_OF_BOUNDS - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- IndexAwarePredicate - Interface in com.hazelcast.query
- 
This interface is used for create filterable Predicates. 
- indexes - Variable in class com.hazelcast.map.impl.MapContainer
-  
- Indexes - Class in com.hazelcast.query.impl
- 
Contains all indexes for a data-structure, e.g. 
- Indexes(SerializationService, Extractors) - Constructor for class com.hazelcast.query.impl.Indexes
-  
- IndexImpl - Class in com.hazelcast.query.impl
-  
- IndexImpl(String, boolean, SerializationService, Extractors) - Constructor for class com.hazelcast.query.impl.IndexImpl
-  
- IndexImpl.NullObject - Class in com.hazelcast.query.impl
-  
- IndexImpl.NullObject() - Constructor for class com.hazelcast.query.impl.IndexImpl.NullObject
-  
- indexOf(Object) - Method in class com.hazelcast.client.proxy.ClientListProxy
-  
- indexOf(boolean, Data) - Method in class com.hazelcast.collection.impl.list.ListContainer
-  
- indexOf(Object) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
-  
- indexOf(String, char, int) - Static method in class com.hazelcast.util.StringUtil
- 
Like a String.indexOf but without MIN_SUPPLEMENTARY_CODE_POINT handling 
- indexOf(String, char) - Static method in class com.hazelcast.util.StringUtil
- 
Like a String.indexOf but without MIN_SUPPLEMENTARY_CODE_POINT handling 
- IndexStore - Interface in com.hazelcast.query.impl
- 
This interface stores indexes of Query. 
- InflatableSet<T> - Class in com.hazelcast.util.collection
- 
Provides fast  Set implementation for cases where items are known to not
 contain duplicates. 
- InflatableSet.Builder<T> - Class in com.hazelcast.util.collection
- 
Builder for  InflatableSet
 This is the only way to create a new instance of InflatableSet 
- info(String) - Method in class com.hazelcast.logging.AbstractLogger
-  
- info(String) - Method in interface com.hazelcast.logging.ILogger
- 
- init() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- init(NodeEngine, Properties) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- init() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-  
- init() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Initializes record store. 
- init() - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache
-  
- init() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- init(NodeEngine, Properties) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- init(Cluster, ClientConfig) - Method in interface com.hazelcast.client.LoadBalancer
- 
Initializes the LoadBalancer. 
- init(long) - Method in class com.hazelcast.client.proxy.ClientIdGeneratorProxy
-  
- init(int) - Method in class com.hazelcast.client.proxy.ClientSemaphoreProxy
-  
- init() - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- init() - Method in class com.hazelcast.client.spi.impl.ClusterListenerSupport
-  
- init(InitialMembershipEvent) - Method in class com.hazelcast.client.spi.impl.listener.ClientSmartListenerService
-  
- init(ClientConfig) - Method in class com.hazelcast.client.spi.ProxyManager
-  
- init(Cluster, ClientConfig) - Method in class com.hazelcast.client.util.AbstractLoadBalancer
-  
- init(InitialMembershipEvent) - Method in class com.hazelcast.client.util.AbstractLoadBalancer
-  
- init(Cluster, ClientConfig) - Method in class com.hazelcast.client.util.StaticLB
-  
- init(NodeEngine, Properties) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- init(NodeEngine) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- init(NodeEngine, Properties) - Method in class com.hazelcast.collection.impl.collection.CollectionService
-  
- init(boolean) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- init(NodeEngine, Properties) - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- init(NodeEngine, Properties) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-  
- init(NodeEngine, Properties) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-  
- init(NodeEngine, Properties) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-  
- init(long) - Method in class com.hazelcast.concurrent.idgen.IdGeneratorImpl
-  
- init(long) - Method in class com.hazelcast.concurrent.idgen.IdGeneratorProxy
-  
- init(NodeEngine, Properties) - Method in class com.hazelcast.concurrent.idgen.IdGeneratorService
-  
- init(NodeEngine, Properties) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-  
- init(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-  
- init(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-  
- init(NodeEngine, Properties) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-  
- init(long) - Method in interface com.hazelcast.core.IdGenerator
- 
Try to initialize this IdGenerator instance with the given id. 
- init(InitialMembershipEvent) - Method in interface com.hazelcast.core.InitialMembershipListener
- 
Called when this listener is registered. 
- init(int) - Method in interface com.hazelcast.core.ISemaphore
- 
Try to initialize this ISemaphore instance with the given permit count 
- init(HazelcastInstance, Properties, String) - Method in interface com.hazelcast.core.MapLoaderLifecycleSupport
- 
Initializes this MapLoader implementation. 
- init(NodeEngine, Properties) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-  
- init(TextReadHandler, long) - Method in class com.hazelcast.internal.ascii.AbstractTextCommand
-  
- init(TextReadHandler, long) - Method in interface com.hazelcast.internal.ascii.TextCommand
-  
- init() - Method in class com.hazelcast.internal.management.TimedMemberStateFactory
-  
- init(Object, Object, SerializationService) - Method in class com.hazelcast.map.impl.LazyMapEntry
-  
- init(NodeEngine, Properties) - Method in class com.hazelcast.map.impl.MapManagedService
-  
- init(NodeEngine, Properties) - Method in class com.hazelcast.map.impl.MapService
-  
- init(HazelcastInstance, Properties, String) - Method in class com.hazelcast.map.impl.MapStoreWrapper
-  
- init() - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- init() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
- 
Initialize the recordStore after creation 
- init(NodeEngine, Properties) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-  
- init(NodeEngine, Properties) - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- init(byte[], int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- init(Properties) - Method in interface com.hazelcast.nio.SocketInterceptor
- 
- init(Properties) - Method in class com.hazelcast.nio.ssl.BasicSSLContextFactory
-  
- init(Properties) - Method in interface com.hazelcast.nio.ssl.SSLContextFactory
- 
Initializes this class with config from  SSLConfig
- init() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingSocketReader
-  
- init() - Method in interface com.hazelcast.nio.tcp.SocketReader
- 
Initializes this SocketReader. 
- init() - Method in class com.hazelcast.nio.tcp.spinning.SpinningSocketReader
-  
- init(NodeEngine, Properties) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- init(SerializationService, Data, Object, Extractors) - Method in class com.hazelcast.query.impl.CachedQueryEntry
-  
- init(SerializationService, Data, Object, Extractors) - Method in class com.hazelcast.query.impl.QueryEntry
- 
It may be useful to use this initmethod in some cases that same instance of this class can be used
 instead of creating a new one for every iteration when scanning large data sets, for example:
 
- init(NodeEngine, Properties) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- init(NodeEngine) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-  
- init(NodeEngine, Properties) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-  
- init() - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-  
- init(NodeEngine, Properties) - Method in interface com.hazelcast.spi.ManagedService
- 
Initializes this ManagedService 
- init() - Method in class com.hazelcast.spring.HazelcastNamespaceHandler
-  
- init(NodeEngine, Properties) - Method in class com.hazelcast.topic.impl.TopicService
-  
- init(NodeEngine, Properties) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-  
- init(NodeEngine, Properties) - Method in class com.hazelcast.transaction.impl.xa.XAService
-  
- init(Node, String, String, String...) - Method in interface com.hazelcast.wan.WanReplicationEndpoint
- 
Initializes the endpoint using the given arguments. 
- init() - Method in class com.hazelcast.web.ClusteredSessionService
-  
- init(FilterConfig) - Method in class com.hazelcast.web.WebFilter
-  
- INIT_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-  
- INIT_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-  
- InitBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
-  
- InitBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.InitBackupOperation
-  
- InitBackupOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.InitBackupOperation
-  
- InitConnectionTask - Class in com.hazelcast.nio.tcp
- 
A Task that initiates a TcpConnection to be build. 
- InitConnectionTask(TcpIpConnectionManager, Address, boolean) - Constructor for class com.hazelcast.nio.tcp.InitConnectionTask
-  
- initFactories() - Method in class com.hazelcast.client.impl.protocol.MessageTaskFactoryImpl
-  
- INITIAL_BACKOFF_MS - Static variable in class com.hazelcast.client.proxy.ClientReliableTopicProxy
-  
- INITIAL_BACKOFF_MS - Static variable in class com.hazelcast.topic.impl.reliable.ReliableTopicProxy
-  
- INITIAL_CAPACITY - Static variable in class com.hazelcast.client.impl.protocol.util.BufferBuilder
- 
Buffer's default initial capacity 
- INITIAL_CAPACITY - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-  
- INITIAL_MEMBERS - Static variable in class com.hazelcast.cluster.client.ClientInitialMembershipEvent
-  
- INITIAL_MEMBERSHIP_EVENT - Static variable in class com.hazelcast.cluster.impl.ClusterDataSerializerHook
-  
- INITIAL_MEMORY_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
- 
Initial memory size in megabytes 
- initialClusterState(ClusterState) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- initialize() - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-  
- initialize(Object) - Method in interface com.hazelcast.core.ManagedContext
- 
Initialize the given object instance. 
- initialize(Object) - Method in class com.hazelcast.instance.HazelcastManagedContext
-  
- initialize() - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- initialize(Context<KeyOut, ValueOut>) - Method in interface com.hazelcast.mapreduce.LifecycleMapper
- 
This method is called before the  Mapper.map(Object, Object, Context) method is executed for every value and
 can be used to initialize the internal state of the mapper or to emit a special value. 
- initialize(Context<KeyOut, ValueOut>) - Method in class com.hazelcast.mapreduce.LifecycleMapperAdapter
- 
This method is called before the  Mapper.map(Object, Object, Context) method is executed for every value and
 can be used to initialize the internal state of the mapper or to emit a special value. 
- initialize() - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-  
- initialize(Collection<MemberGroup>, int) - Method in interface com.hazelcast.partition.impl.PartitionStateGenerator
- 
Returns the initial layout for the partitions. 
- initialize(Collection<MemberGroup>, int) - Method in class com.hazelcast.partition.impl.PartitionStateGeneratorImpl
-  
- initialize() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-  
- initialize() - Method in interface com.hazelcast.spi.InitializingObject
-  
- initialize(Object) - Method in class com.hazelcast.spring.context.SpringManagedContext
-  
- initialize() - Method in class com.hazelcast.topic.impl.TopicProxySupport
-  
- initializeDistributedObject(String, String) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-  
- initializeDistributedObject(String, String) - Method in interface com.hazelcast.spi.ProxyService
-  
- InitializeDistributedObjectOperation - Class in com.hazelcast.spi.impl.proxyservice.impl.operations
-  
- InitializeDistributedObjectOperation() - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.operations.InitializeDistributedObjectOperation
-  
- InitializeDistributedObjectOperation(String, String) - Constructor for class com.hazelcast.spi.impl.proxyservice.impl.operations.InitializeDistributedObjectOperation
-  
- initializeListeners(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- initializeSelectors(HazelcastClientInstanceImpl) - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-  
- InitializingObject - Interface in com.hazelcast.spi
- 
Can be implemented by DistributedObject (proxies) to indicate that they want to be initialized. 
- InitialMembershipEvent - Class in com.hazelcast.core
- 
- InitialMembershipEvent(Cluster, Set<Member>) - Constructor for class com.hazelcast.core.InitialMembershipEvent
-  
- InitialMembershipListener - Interface in com.hazelcast.core
- 
- initialOutputBufferSize - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- initMask(String[]) - Method in class com.hazelcast.security.permission.AtomicLongPermission
-  
- initMask(String[]) - Method in class com.hazelcast.security.permission.AtomicReferencePermission
-  
- initMask(String[]) - Method in class com.hazelcast.security.permission.CachePermission
-  
- initMask(String[]) - Method in class com.hazelcast.security.permission.CountDownLatchPermission
-  
- initMask(String[]) - Method in class com.hazelcast.security.permission.ExecutorServicePermission
-  
- initMask(String[]) - Method in class com.hazelcast.security.permission.InstancePermission
- 
init mask 
- initMask(String[]) - Method in class com.hazelcast.security.permission.ListPermission
-  
- initMask(String[]) - Method in class com.hazelcast.security.permission.LockPermission
-  
- initMask(String[]) - Method in class com.hazelcast.security.permission.MapPermission
-  
- initMask(String[]) - Method in class com.hazelcast.security.permission.MapReducePermission
-  
- initMask(String[]) - Method in class com.hazelcast.security.permission.QueuePermission
-  
- initMask(String[]) - Method in class com.hazelcast.security.permission.ReplicatedMapPermission
-  
- initMask(String[]) - Method in class com.hazelcast.security.permission.RingBufferPermission
-  
- initMask(String[]) - Method in class com.hazelcast.security.permission.SemaphorePermission
-  
- initMask(String[]) - Method in class com.hazelcast.security.permission.TopicPermission
-  
- InitOperation - Class in com.hazelcast.concurrent.semaphore.operations
-  
- InitOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.InitOperation
-  
- InitOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.InitOperation
-  
- initPartitionsContainers() - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- initProperties(Properties, HazelcastProperty[]) - Method in class com.hazelcast.instance.HazelcastProperties
- 
Creates a container with configured Hazelcast properties. 
- InitRequest - Class in com.hazelcast.concurrent.semaphore.client
-  
- InitRequest() - Constructor for class com.hazelcast.concurrent.semaphore.client.InitRequest
-  
- InitRequest(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.client.InitRequest
-  
- initSocket(Socket) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- initWanReplication(NodeEngine) - Method in class com.hazelcast.map.impl.MapContainer
-  
- inMemoryFormat - Variable in class com.hazelcast.cache.impl.client.AbstractCacheRequest
-  
- inMemoryFormat - Variable in class com.hazelcast.cache.impl.record.CacheRecordFactory
-  
- InMemoryFormat - Enum in com.hazelcast.config
- 
Storage format type of values stored in cluster 
- InMemoryXmlConfig - Class in com.hazelcast.config
- 
Creates a  Config loaded from an in-memory Hazelcast XML String. 
- InMemoryXmlConfig(String) - Constructor for class com.hazelcast.config.InMemoryXmlConfig
- 
Creates a Config from the provided XML string and uses the System.properties to resolve variables
 in the XML. 
- InMemoryXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.InMemoryXmlConfig
- 
Creates a Config from the provided XML string and properties to resolve the variables in the XML. 
- innerBeforeRun() - Method in class com.hazelcast.map.impl.operation.EntryBackupOperation
-  
- innerBeforeRun() - Method in class com.hazelcast.map.impl.operation.EntryOperation
-  
- innerBeforeRun() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-  
- innerBeforeRun() - Method in class com.hazelcast.map.impl.operation.MapOperation
-  
- innerBeforeRun() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-  
- innerBeforeRun() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-  
- innerBeforeRun() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-  
- innerBeforeRun() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-  
- innerBeforeRun() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.AbstractTransactionalMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCommitMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionCreateMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transaction.TransactionRollbackMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListAddMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListRemoveMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionallist.TransactionalListSizeMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapContainsKeyMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapDeleteMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetForUpdateMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapGetMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapIsEmptyMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapKeySetWithPredicateMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutIfAbsentMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapPutMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveIfSameMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapRemoveMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceIfSameMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapReplaceMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSetMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapSizeMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmap.TransactionalMapValuesWithPredicateMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapGetMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapPutMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveEntryMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapRemoveMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapSizeMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalmultimap.TransactionalMultiMapValueCountMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueOfferMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePeekMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueuePollMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueSizeMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalqueue.TransactionalQueueTakeMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetAddMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetRemoveMessageTask
-  
- innerCall() - Method in class com.hazelcast.client.impl.protocol.task.transactionalset.TransactionalSetSizeMessageTask
-  
- innerCall() - Method in class com.hazelcast.collection.impl.txnlist.client.TxnListAddRequest
-  
- innerCall() - Method in class com.hazelcast.collection.impl.txnlist.client.TxnListRemoveRequest
-  
- innerCall() - Method in class com.hazelcast.collection.impl.txnlist.client.TxnListSizeRequest
-  
- innerCall() - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnOfferRequest
-  
- innerCall() - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnPeekRequest
-  
- innerCall() - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnPollRequest
-  
- innerCall() - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnSizeRequest
-  
- innerCall() - Method in class com.hazelcast.collection.impl.txnset.client.TxnSetAddRequest
-  
- innerCall() - Method in class com.hazelcast.collection.impl.txnset.client.TxnSetRemoveRequest
-  
- innerCall() - Method in class com.hazelcast.collection.impl.txnset.client.TxnSetSizeRequest
-  
- innerCall() - Method in class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-  
- innerCall() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapGetRequest
-  
- innerCall() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapPutRequest
-  
- innerCall() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveAllRequest
-  
- innerCall() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveRequest
-  
- innerCall() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapSizeRequest
-  
- innerCall() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapValueCountRequest
-  
- innerCall() - Method in class com.hazelcast.transaction.client.BaseTransactionRequest
-  
- innerCall() - Method in class com.hazelcast.transaction.client.CommitTransactionRequest
-  
- innerCall() - Method in class com.hazelcast.transaction.client.CreateTransactionRequest
-  
- innerCall() - Method in class com.hazelcast.transaction.client.RollbackTransactionRequest
-  
- innerClose() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- InPredicate - Class in com.hazelcast.query.impl.predicates
- 
In Predicate 
- InPredicate() - Constructor for class com.hazelcast.query.impl.predicates.InPredicate
-  
- InPredicate(String, Comparable...) - Constructor for class com.hazelcast.query.impl.predicates.InPredicate
-  
- inputOutputFactory - Variable in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- InputOutputFactory - Interface in com.hazelcast.internal.serialization
-  
- insert(Object, Object, Object) - Method in interface com.hazelcast.hibernate.access.AccessDelegate
- 
Called after an item has been inserted (before the transaction completes),
 instead of calling evict(). 
- insert(Object, Object, Object) - Method in class com.hazelcast.hibernate.access.NonStrictReadWriteAccessDelegate
- 
Called after an item has been inserted (before the transaction completes),
 instead of calling evict(). 
- insert(Object, Object, Object) - Method in class com.hazelcast.hibernate.access.ReadOnlyAccessDelegate
- 
Called after an item has been inserted (before the transaction completes),
 instead of calling evict(). 
- insert(Object, Object, Object) - Method in class com.hazelcast.hibernate.access.ReadWriteAccessDelegate
- 
This is an asynchronous cache access strategy. 
- insert(Object, Object, Object) - Method in class com.hazelcast.hibernate.distributed.IMapRegionCache
-  
- insert(Object, Object, Object) - Method in class com.hazelcast.hibernate.local.LocalRegionCache
-  
- insert(Object, Object, Object) - Method in class com.hazelcast.hibernate.region.EntityRegionAccessStrategyAdapter
-  
- insert(Object, Object) - Method in class com.hazelcast.hibernate.region.NaturalIdRegionAccessStrategyAdapter
-  
- insert(Object, Object, Object) - Method in class com.hazelcast.hibernate.region.NaturalIdRegionAccessStrategyAdapter
-  
- insert(Object, Object, Object) - Method in interface com.hazelcast.hibernate.RegionCache
-  
- insertMigratedData(int, Map<String, Map>) - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- insertMigrationData(Map<String, SemaphoreContainer>) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-  
- inspectOutputMemoryError(Throwable) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
-  
- instance - Variable in class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
-  
- INSTANCE - Static variable in class com.hazelcast.partition.strategy.StringAndPartitionAwarePartitioningStrategy
-  
- INSTANCE - Static variable in class com.hazelcast.partition.strategy.StringPartitioningStrategy
-  
- INSTANCE - Static variable in class com.hazelcast.query.impl.FalsePredicate
- 
An instance of the FalsePredicate. 
- INSTANCE - Static variable in class com.hazelcast.query.TruePredicate
- 
An instance of the TruePredicate. 
- INSTANCE - Static variable in class com.hazelcast.spi.impl.eventservice.impl.TrueEventFilter
-  
- InstanceMBean - Class in com.hazelcast.jmx
- 
- InstanceMBean(HazelcastInstanceImpl, ManagementService) - Constructor for class com.hazelcast.jmx.InstanceMBean
-  
- instanceOf(Class) - Static method in class com.hazelcast.query.Predicates
-  
- INSTANCEOF_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
-  
- InstanceOfPredicate - Class in com.hazelcast.query.impl.predicates
- 
Predicate version of `instaceof` operator from Java. 
- InstanceOfPredicate(Class) - Constructor for class com.hazelcast.query.impl.predicates.InstanceOfPredicate
-  
- InstanceOfPredicate() - Constructor for class com.hazelcast.query.impl.predicates.InstanceOfPredicate
-  
- InstancePermission - Class in com.hazelcast.security.permission
-  
- InstancePermission(String, String...) - Constructor for class com.hazelcast.security.permission.InstancePermission
-  
- Int2ObjectHashMap<V> - Class in com.hazelcast.util.collection
- 
Map implementation specialised for int keys using open addressing and
 linear probing for cache efficient access. 
- Int2ObjectHashMap() - Constructor for class com.hazelcast.util.collection.Int2ObjectHashMap
-  
- Int2ObjectHashMap(int, double) - Constructor for class com.hazelcast.util.collection.Int2ObjectHashMap
- 
Construct a new map allowing a configuration for initial capacity and load factor. 
- Int2ObjectHashMap.EntryIterator<V> - Class in com.hazelcast.util.collection
-  
- Int2ObjectHashMap.EntryIterator() - Constructor for class com.hazelcast.util.collection.Int2ObjectHashMap.EntryIterator
-  
- Int2ObjectHashMap.KeyIterator - Class in com.hazelcast.util.collection
-  
- Int2ObjectHashMap.KeyIterator() - Constructor for class com.hazelcast.util.collection.Int2ObjectHashMap.KeyIterator
-  
- Int2ObjectHashMap.KeySet - Class in com.hazelcast.util.collection
-  
- Int2ObjectHashMap.KeySet() - Constructor for class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
-  
- Int2ObjectHashMap.ValueIterator<T> - Class in com.hazelcast.util.collection
-  
- Int2ObjectHashMap.ValueIterator() - Constructor for class com.hazelcast.util.collection.Int2ObjectHashMap.ValueIterator
-  
- int32Get(int) - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- int32Set(int, int) - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- int64Get(int) - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- int64Set(int, long) - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- INT_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
-  
- INT_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
-  
- INT_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
- 
Integer size in bytes 
- INTEGER - Static variable in class com.hazelcast.client.impl.protocol.ResponseMessageConst
-  
- INTEGER_AVG_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- INTEGER_AVG_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- INTEGER_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
-  
- INTEGER_MAX_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- INTEGER_MAX_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- INTEGER_MIN_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- INTEGER_MIN_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- INTEGER_SUM_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- INTEGER_SUM_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- integerAvg() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
- 
Returns an aggregation to calculate the integer average of all supplied values.
 This aggregation is similar to:
 
- IntegerAvgAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
- 
The predefined average aggregation for values of type integer. 
- IntegerAvgAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.IntegerAvgAggregation
-  
- integerMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
- 
Returns an aggregation to find the integer maximum of all supplied values.
 This aggregation is similar to:
 
- IntegerMaxAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
- 
The predefined maximum aggregation for values of type integer. 
- IntegerMaxAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.IntegerMaxAggregation
-  
- integerMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
- 
Returns an aggregation to find the integer minimum of all supplied values.
 This aggregation is similar to:
 
- IntegerMinAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
- 
The predefined minimum aggregation for values of type integer. 
- IntegerMinAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.IntegerMinAggregation
-  
- integerSum() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
- 
Returns an aggregation to calculate the integer sum of all supplied values.
 This aggregation is similar to:
 
- IntegerSumAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
- 
The predefined sum aggregation for values of type integer. 
- IntegerSumAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.IntegerSumAggregation
-  
- interceptAfter(Credentials, String, String, String) - Method in interface com.hazelcast.security.SecurityContext
- 
intercepts a request after process if any  SecurityInterceptor configured
 Any exception thrown during interception will be ignored 
- interceptAfterGet(String, Object) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
-  
- interceptAfterPut(String, Object) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
-  
- interceptAfterRemove(String, Object) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
-  
- interceptBefore(Credentials, String, String, String, Object[]) - Method in interface com.hazelcast.security.SecurityContext
- 
- interceptGet(String, Object) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
-  
- interceptGet(Object) - Method in interface com.hazelcast.map.MapInterceptor
- 
Intercept the get operation before returning value. 
- InterceptorRegistry - Class in com.hazelcast.map.impl
- 
Registry for IMapinterceptors
 Interceptors are read mostly and this registry keeps all registered interceptor in an array to easily iterate on them.
 
- InterceptorRegistry() - Constructor for class com.hazelcast.map.impl.InterceptorRegistry
-  
- interceptorRegistry - Variable in class com.hazelcast.map.impl.MapContainer
-  
- interceptPut(String, Object, Object) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
-  
- interceptPut(Object, Object) - Method in interface com.hazelcast.map.MapInterceptor
- 
Intercept the put operation before modifying the map data. 
- interceptRemove(String, Object) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
-  
- interceptRemove(Object) - Method in interface com.hazelcast.map.MapInterceptor
- 
Intercept remove operation before removing the data. 
- interceptSocket(Socket, boolean) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- InterfacesConfig - Class in com.hazelcast.config
- 
Contains the configuration for Interfaces. 
- InterfacesConfig() - Constructor for class com.hazelcast.config.InterfacesConfig
-  
- IntermediateChunkNotification<KeyOut,Value> - Class in com.hazelcast.mapreduce.impl.notification
- 
Notification that is fired every time the chunk limit is reached and is send to the reducers 
- IntermediateChunkNotification() - Constructor for class com.hazelcast.mapreduce.impl.notification.IntermediateChunkNotification
-  
- IntermediateChunkNotification(Address, String, String, Map<KeyOut, Value>, int) - Constructor for class com.hazelcast.mapreduce.impl.notification.IntermediateChunkNotification
-  
- InternalCachePartitionLostListenerAdapter - Class in com.hazelcast.cache.impl.event
-  
- InternalCachePartitionLostListenerAdapter(CachePartitionLostListener) - Constructor for class com.hazelcast.cache.impl.event.InternalCachePartitionLostListenerAdapter
-  
- InternalCompletableFuture<E> - Interface in com.hazelcast.spi
- 
A  ICompletableFuture with more functionality like getting
 the result without needing to deal with checked exceptions. 
- InternalEventService - Interface in com.hazelcast.spi.impl.eventservice
- 
The InternalEventService is an  EventService interface that adds additional capabilities
 we don't want to expose to the end user. 
- InternalExecutionService - Interface in com.hazelcast.spi.impl.executionservice
- 
- InternalLockNamespace - Class in com.hazelcast.concurrent.lock
-  
- InternalLockNamespace() - Constructor for class com.hazelcast.concurrent.lock.InternalLockNamespace
-  
- InternalLockNamespace(String) - Constructor for class com.hazelcast.concurrent.lock.InternalLockNamespace
-  
- InternalMapListenerAdapter - Class in com.hazelcast.map.impl
- 
- InternalMultiMap<K,V> - Class in com.hazelcast.util.collection
- 
Simplistic implementation of MultiMap. 
- InternalMultiMap() - Constructor for class com.hazelcast.util.collection.InternalMultiMap
-  
- InternalOperationService - Interface in com.hazelcast.spi.impl.operationservice
- 
This is the interface that needs to be implemented by actual InternalOperationService. 
- InternalPartition - Interface in com.hazelcast.partition
- 
Represents a Partition. 
- InternalPartitionLostEvent - Class in com.hazelcast.partition
- 
Internal event that is dispatched to @see com.hazelcast.spi.PartitionAwareService#onPartitionLost()
  
 It contains the partition id, number of replicas that is lost and the address of node that detects the partition lost 
- InternalPartitionLostEvent() - Constructor for class com.hazelcast.partition.InternalPartitionLostEvent
-  
- InternalPartitionLostEvent(int, int, Address) - Constructor for class com.hazelcast.partition.InternalPartitionLostEvent
-  
- InternalPartitionService - Interface in com.hazelcast.partition
-  
- InternalPartitionServiceImpl - Class in com.hazelcast.partition.impl
- 
- InternalPartitionServiceImpl(Node) - Constructor for class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- InternalPartitionServiceState - Enum in com.hazelcast.partition.impl
-  
- InternalProxyService - Interface in com.hazelcast.spi.impl.proxyservice
- 
- InternalReplicatedMapStorage<K,V> - Class in com.hazelcast.replicatedmap.impl.record
- 
This class is meant to encapsulate the actual storage system and support automatic waiting for finishing load operations if
 configured in the  ReplicatedMapConfig
- InternalReplicatedMapStorage() - Constructor for class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
-  
- InternalWaitNotifyService - Interface in com.hazelcast.spi.impl.waitnotifyservice
-  
- interruptAllPartitionThreads() - Method in class com.hazelcast.spi.impl.operationexecutor.classic.ClassicOperationExecutor
-  
- interruptAllPartitionThreads() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
- 
Interrupts all partition threads. 
- INTERRUPTED - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- IntFunction<R> - Interface in com.hazelcast.util.function
- 
Represents a function that accepts an int-valued argument and produces a
 result. 
- IntHashSet - Class in com.hazelcast.util.collection
- 
Simple fixed-size int hashset. 
- IntHashSet(int, int) - Constructor for class com.hazelcast.util.collection.IntHashSet
-  
- IntIterator - Class in com.hazelcast.util.collection
- 
An iterator for a sequence of primitive integers. 
- IntIterator(int, int[]) - Constructor for class com.hazelcast.util.collection.IntIterator
- 
Construct an  Iterator over an array of primitives ints. 
- INVALID_ADDRESS - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- INVALID_CONFIGURATION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- INVALID_HZ_INSTANCE_SPECIFICATION_MESSAGE - Static variable in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-  
- invalidate(String, Data, String) - Method in class com.hazelcast.map.impl.nearcache.BatchInvalidator
-  
- invalidate(String, List<Data>, String) - Method in class com.hazelcast.map.impl.nearcache.BatchInvalidator
-  
- invalidate(String, Data, String) - Method in interface com.hazelcast.map.impl.nearcache.NearCacheInvalidator
- 
Invalidates local and remote near-caches. 
- invalidate(String, List<Data>, String) - Method in interface com.hazelcast.map.impl.nearcache.NearCacheInvalidator
- 
Invalidates local and remote near-caches. 
- invalidate(String, Data, String) - Method in class com.hazelcast.map.impl.nearcache.NonStopInvalidator
-  
- invalidate(String, List<Data>, String) - Method in class com.hazelcast.map.impl.nearcache.NonStopInvalidator
-  
- invalidate() - Method in class com.hazelcast.partition.MigrationInfo
-  
- invalidate() - Method in class com.hazelcast.spi.AbstractDistributedObject
-  
- invalidate() - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- invalidateAllEntries() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- invalidateAllEntries(String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- invalidateCache(Data) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- invalidateCache(Collection<Data>) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- invalidateCache(Iterable<Data>) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- invalidateClient(String, Data, List<Data>, String) - Method in class com.hazelcast.map.impl.nearcache.NonStopInvalidator
-  
- invalidateEntry(Data, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- invalidateEntry(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- invalidateLocal(String, Data, List<Data>) - Method in class com.hazelcast.map.impl.nearcache.AbstractNearCacheInvalidator
-  
- invalidateMember(BatchNearCacheInvalidation) - Method in class com.hazelcast.map.impl.nearcache.BatchInvalidator
-  
- invalidateMember(String, Data, List<Data>, String) - Method in class com.hazelcast.map.impl.nearcache.NonStopInvalidator
-  
- invalidateNearCache(Data) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- invalidateNearCache(Collection<Data>) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- invalidateNearCache(List<Data>) - Method in class com.hazelcast.map.impl.operation.MapOperation
-  
- invalidateNearCache(Data) - Method in class com.hazelcast.map.impl.operation.MapOperation
-  
- Invalidation - Class in com.hazelcast.hibernate.local
- 
An invalidation messages 
- Invalidation() - Constructor for class com.hazelcast.hibernate.local.Invalidation
-  
- Invalidation(Object, Object) - Constructor for class com.hazelcast.hibernate.local.Invalidation
-  
- INVALIDATION - Static variable in class com.hazelcast.hibernate.serialization.HibernateDataSerializerHook
-  
- Invalidation - Class in com.hazelcast.map.impl.nearcache
- 
Root interface for near-cache invalidation data. 
- Invalidation() - Constructor for class com.hazelcast.map.impl.nearcache.Invalidation
-  
- Invalidation(String, String) - Constructor for class com.hazelcast.map.impl.nearcache.Invalidation
-  
- INVALIDATION_MESSAGE - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- InvalidationListener - Interface in com.hazelcast.map.impl.nearcache
- 
Used to receive invalidation events from an  IMap
 For example, a client near-cache implementation can listen changes in IMap data and
 can remove stale data in its own cache. 
- invalidationListenerCount - Variable in class com.hazelcast.map.impl.MapContainer
- 
- invalidationListenerId - Variable in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- InvalidConfigurationException - Exception in com.hazelcast.config
- 
A InvalidConfigurationException is thrown when there is an Invalid Configuration. 
- InvalidConfigurationException(String) - Constructor for exception com.hazelcast.config.InvalidConfigurationException
- 
Creates a InvalidConfigurationException with the given message. 
- InvalidConfigurationException(String, Throwable) - Constructor for exception com.hazelcast.config.InvalidConfigurationException
- 
** Constructs a new runtime exception with the specified detail message and
 cause. 
- invertBit(byte, int) - Static method in class com.hazelcast.nio.Bits
- 
Inverts n-th bit of the byte value 
- invertBit(int, int) - Static method in class com.hazelcast.nio.Bits
- 
Inverts n-th bit of the integer value 
- INVOCATION_TRY_COUNT - Static variable in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- InvocationBuilder - Class in com.hazelcast.spi
- 
The InvocationBuilder is responsible for building an invocation of an operation and invoking it. 
- InvocationBuilder(NodeEngineImpl, String, Operation, int, Address) - Constructor for class com.hazelcast.spi.InvocationBuilder
- 
Creates an InvocationBuilder 
- InvocationBuilderImpl - Class in com.hazelcast.spi.impl.operationservice.impl
- 
- InvocationBuilderImpl(NodeEngineImpl, String, Operation, int) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.InvocationBuilderImpl
-  
- InvocationBuilderImpl(NodeEngineImpl, String, Operation, Address) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.InvocationBuilderImpl
-  
- InvocationClientRequest - Class in com.hazelcast.client.impl.client
-  
- InvocationClientRequest() - Constructor for class com.hazelcast.client.impl.client.InvocationClientRequest
-  
- InvocationMonitor - Class in com.hazelcast.spi.impl.operationservice.impl
- 
The InvocationMonitor monitors all pending invocations and determines if there are any problems like timeouts. 
- InvocationMonitor(InvocationRegistry, ILogger, GroupProperties, HazelcastThreadGroup, ExecutionService, MetricsRegistry) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.InvocationMonitor
-  
- InvocationRegistry - Class in com.hazelcast.spi.impl.operationservice.impl
- 
The InvocationsRegistry is responsible for the registration of all pending invocations. 
- InvocationRegistry(NodeEngineImpl, ILogger, BackpressureRegulator, int) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
-  
- invocations - Variable in class com.hazelcast.internal.management.dto.SlowOperationDTO
-  
- invocations() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
-  
- invocationService - Variable in class com.hazelcast.client.spi.impl.listener.ClientListenerServiceImpl
-  
- invoke(Data, EntryProcessor, Object[], int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- invoke(K, EntryProcessor<K, V, T>, Object...) - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- invoke(Data, EntryProcessor, Object[], int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Invokes an EntryProcessoragainst theCache.Entryspecified by
 the provided key.
 
- invoke(K, EntryProcessor<K, V, T>, Object...) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- invoke() - Method in class com.hazelcast.client.impl.client.InvocationClientRequest
-  
- invoke(ClientRequest) - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
-  
- invoke(ClientMessage, int) - Method in class com.hazelcast.client.proxy.ClientRingbufferProxy
-  
- invoke(ClientMessage, Object) - Method in class com.hazelcast.client.spi.ClientProxy
-  
- invoke(ClientMessage) - Method in class com.hazelcast.client.spi.ClientProxy
-  
- invoke() - Method in class com.hazelcast.client.spi.impl.ClientInvocation
-  
- invoke(CollectionOperation) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-  
- invoke() - Method in class com.hazelcast.executor.impl.client.CancellationRequest
-  
- invoke(String, Object[], String[]) - Method in class com.hazelcast.jmx.HazelcastMBean
-  
- invoke() - Method in class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-  
- invoke(Operation, int) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- invoke(Collator) - Method in class com.hazelcast.mapreduce.impl.AbstractJob
-  
- invoke() - Method in class com.hazelcast.mapreduce.impl.client.ClientCancellationRequest
-  
- invoke() - Method in class com.hazelcast.mapreduce.impl.client.ClientJobProcessInformationRequest
-  
- invoke() - Method in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-  
- invoke(Collator) - Method in class com.hazelcast.mapreduce.impl.task.KeyValueJob
-  
- invoke() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationBuilderImpl
-  
- invoke() - Method in class com.hazelcast.spi.InvocationBuilder
-  
- invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- invokeAll(Collection<? extends Callable<T>>) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- invokeAll(Collection<? extends Callable<T>>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- invokeAll(Collection<? extends Callable<T>>) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-  
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-  
- invokeAny(Collection<? extends Callable<T>>) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- invokeAny(Collection<? extends Callable<T>>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- invokeAny(Collection<? extends Callable<T>>) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-  
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-  
- invokeMethod(Object, String) - Static method in class com.hazelcast.query.impl.getters.ReflectionHelper
-  
- invokeOnAllPartitions(String, OperationFactory) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- invokeOnAllPartitions(String, OperationFactory) - Method in interface com.hazelcast.spi.OperationService
- 
Invokes a set of operation on each partition. 
- invokeOnConnection(ClientInvocation, ClientConnection) - Method in interface com.hazelcast.client.spi.ClientInvocationService
-  
- invokeOnConnection(ClientInvocation, ClientConnection) - Method in class com.hazelcast.client.spi.impl.ClientNonSmartInvocationServiceImpl
-  
- invokeOnConnection(ClientInvocation, ClientConnection) - Method in class com.hazelcast.client.spi.impl.ClientSmartInvocationServiceImpl
-  
- invokeOnPartition(ClientMessage, int) - Method in class com.hazelcast.client.spi.ClientProxy
-  
- invokeOnPartition(String, Operation, int) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- invokeOnPartition(String, Operation, int) - Method in interface com.hazelcast.spi.OperationService
-  
- invokeOnPartitionInterruptibly(ClientMessage, int) - Method in class com.hazelcast.client.spi.ClientProxy
-  
- invokeOnPartitionOwner(ClientInvocation, int) - Method in interface com.hazelcast.client.spi.ClientInvocationService
-  
- invokeOnPartitionOwner(ClientInvocation, int) - Method in class com.hazelcast.client.spi.impl.ClientNonSmartInvocationServiceImpl
-  
- invokeOnPartitionOwner(ClientInvocation, int) - Method in class com.hazelcast.client.spi.impl.ClientSmartInvocationServiceImpl
-  
- invokeOnPartitions(String, OperationFactory, Collection<Integer>) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- invokeOnPartitions(String, OperationFactory, Collection<Integer>) - Method in interface com.hazelcast.spi.OperationService
- 
Invokes an set of operation on selected set of partitions
 *  
 This method blocks until all operations complete. 
- invokeOnRandomTarget(ClientInvocation) - Method in interface com.hazelcast.client.spi.ClientInvocationService
-  
- invokeOnRandomTarget(ClientInvocation) - Method in class com.hazelcast.client.spi.impl.ClientNonSmartInvocationServiceImpl
-  
- invokeOnRandomTarget(ClientInvocation) - Method in class com.hazelcast.client.spi.impl.ClientSmartInvocationServiceImpl
-  
- invokeOnTarget(ClientInvocation, Address) - Method in interface com.hazelcast.client.spi.ClientInvocationService
-  
- invokeOnTarget(ClientInvocation, Address) - Method in class com.hazelcast.client.spi.impl.ClientNonSmartInvocationServiceImpl
-  
- invokeOnTarget(ClientInvocation, Address) - Method in class com.hazelcast.client.spi.impl.ClientSmartInvocationServiceImpl
-  
- invokeOnTarget(String, Operation, Address) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- invokeOnTarget(String, Operation, Address) - Method in interface com.hazelcast.spi.OperationService
-  
- invokeQueryAllPartitions(String, Predicate, IterationType) - Method in interface com.hazelcast.map.impl.query.MapQueryEngine
- 
Queries all partitions. 
- invokeQueryAllPartitions(String, Predicate, IterationType) - Method in class com.hazelcast.map.impl.query.MapQueryEngineImpl
-  
- invokeQueryLocalPartitions(String, Predicate, IterationType) - Method in interface com.hazelcast.map.impl.query.MapQueryEngine
- 
Query all local partitions. 
- invokeQueryLocalPartitions(String, Predicate, IterationType) - Method in class com.hazelcast.map.impl.query.MapQueryEngineImpl
-  
- invokeUrgent() - Method in class com.hazelcast.client.spi.impl.ClientInvocation
-  
- IO - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- IO_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
- 
Name of the io executor. 
- IOBalancer - Class in com.hazelcast.nio.tcp.nonblocking.iobalancer
- 
It attempts to detect and fix a selector imbalance problem. 
- IOBalancer(NonBlockingIOThread[], NonBlockingIOThread[], HazelcastThreadGroup, int, LoggingService) - Constructor for class com.hazelcast.nio.tcp.nonblocking.iobalancer.IOBalancer
-  
- IOService - Interface in com.hazelcast.nio
-  
- ioService - Variable in class com.hazelcast.nio.tcp.nonblocking.AbstractHandler
-  
- ioService - Variable in class com.hazelcast.nio.tcp.spinning.AbstractHandler
-  
- ioThread - Variable in class com.hazelcast.nio.tcp.nonblocking.AbstractHandler
-  
- IOThreadingModel - Interface in com.hazelcast.nio.tcp
- 
- IOUtil - Class in com.hazelcast.nio
-  
- IPermissionPolicy - Interface in com.hazelcast.security
- 
IPermissionPolicy is used to determine any  Subject's
 permissions to perform a security sensitive Hazelcast operation. 
- IQueue<E> - Interface in com.hazelcast.core
- 
Concurrent, blocking, distributed, observable queue. 
- is(String) - Method in class com.hazelcast.query.EntryObject
-  
- is(T, T...) - Method in class com.hazelcast.util.StateMachine
- 
Check if current state is one of given states 
- IS_EMPTY - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-  
- IS_EMPTY - Static variable in class com.hazelcast.collection.impl.queue.QueuePortableHook
-  
- IS_EMPTY - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- IS_EMPTY - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-  
- IS_LOCKED - Static variable in class com.hazelcast.concurrent.lock.client.LockPortableHook
-  
- IS_LOCKED - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
-  
- IS_LOCKED - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- IS_LOCKED - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-  
- IS_NULL - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-  
- IS_SHUTDOWN_REQUEST - Static variable in class com.hazelcast.executor.impl.ExecutorPortableHook
-  
- isActive() - Method in class com.hazelcast.client.spi.ClientContext
-  
- isActive() - Method in interface com.hazelcast.nio.IOService
-  
- isActive() - Method in class com.hazelcast.nio.NodeIOService
-  
- isActive() - Method in interface com.hazelcast.osgi.impl.HazelcastInternalOSGiService
- 
Returns the state of the service about if it is active or not. 
- isActive() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- isActive() - Method in interface com.hazelcast.spi.NodeEngine
- 
Deprecated. 
- isAlive() - Method in interface com.hazelcast.client.ClientEndpoint
- 
Checks if the endpoint is alive. 
- isAlive() - Method in interface com.hazelcast.client.connection.ClientConnectionManager
- 
Check if client connection manager is alive. 
- isAlive() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- isAlive() - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-  
- isAlive() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- isAlive() - Method in interface com.hazelcast.nio.Connection
- 
Checks if the Connection is alive. 
- isAlive() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- isAllKeysSupported() - Method in class com.hazelcast.mapreduce.KeyValueSource
- 
 If it is possible to collect all clusterwide available keys for this KeyValueSource
 implementation then this method returns true. 
 If true is returned, a call to  KeyValueSource.getAllKeys() must return all available keys
 to execute a preselection of interesting partitions / nodes based on returns keys. 
- isAllowedToRunInCurrentThread(Operation) - Method in class com.hazelcast.spi.impl.operationexecutor.classic.ClassicOperationExecutor
-  
- isAllowedToRunInCurrentThread(Operation) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
- 
Deprecated. 
- isAllowedToRunOnCallingThread(Operation) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- isAllowedToRunOnCallingThread(Operation) - Method in interface com.hazelcast.spi.OperationService
- 
Deprecated.
since 3.5 since not needed anymore. 
 
- isAllowUnsafe() - Method in class com.hazelcast.config.SerializationConfig
- 
Default value is false. 
- isArrayByteBase64(byte[]) - Static method in class com.hazelcast.util.Base64
-  
- isArrayType() - Method in enum com.hazelcast.nio.serialization.FieldType
-  
- isAsyncFillup() - Method in class com.hazelcast.config.ReplicatedMapConfig
- 
True if the replicated map is available for reads before the initial
 replication is completed, false otherwise. 
- isAuthenticated() - Method in interface com.hazelcast.client.ClientEndpoint
-  
- isAuthenticated() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- isAuthenticatedAsOwner() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- isAuthenticationMessage() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-  
- isAuthenticationMessage() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
-  
- isAvailable() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- isAvailable(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-  
- isBackup(RecordStore) - Method in class com.hazelcast.map.impl.eviction.EvictorImpl
-  
- isBase64(String) - Static method in class com.hazelcast.util.Base64
- 
Tests a string to see if it is valid Base64 
- isBase64(byte) - Static method in class com.hazelcast.util.Base64
-  
- isBinary() - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
-  
- isBinary() - Method in class com.hazelcast.config.MultiMapConfig
- 
Checks if the MultiMap is in binary (serialized) form. 
- isBinary() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-  
- isBinary() - Method in enum com.hazelcast.nio.ConnectionType
-  
- isBitSet(int, int) - Static method in class com.hazelcast.nio.Bits
- 
Returns true if n-th bit of the value is set, false otherwise 
- isBlacklisted(Address) - Method in class com.hazelcast.cluster.impl.AbstractJoiner
-  
- isBlacklisted(Address) - Method in interface com.hazelcast.cluster.Joiner
- 
Checks if an address is blacklisted. 
- isBlocking() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-  
- isBlocking() - Method in interface com.hazelcast.nio.tcp.IOThreadingModel
- 
Tells whether or not every I/O operation on SocketChannel should block until it completes. 
- isBlocking() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingIOThreadingModel
-  
- isBlocking() - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-  
- isBlocking() - Method in class com.hazelcast.nio.tcp.spinning.SpinningIOThreadingModel
-  
- isCachedNull(Object) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- isCacheLocalEntries() - Method in class com.hazelcast.config.NearCacheConfig
- 
If true, cache local entries also. 
- isCallTimedOut(Operation) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- isCallTimedOut(Operation) - Method in interface com.hazelcast.spi.impl.operationservice.InternalOperationService
- 
Checks if this call is timed out. 
- isCancelled() - Method in class com.hazelcast.client.spi.impl.ClientInvocationFuture
-  
- isCancelled() - Method in class com.hazelcast.client.util.ClientCancellableDelegatingFuture
-  
- isCancelled() - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-  
- isCancelled() - Method in class com.hazelcast.mapreduce.impl.task.MappingPhase
-  
- isCancelled() - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-  
- isCancelled() - Method in class com.hazelcast.util.executor.CompletedFuture
-  
- isCancelled() - Method in class com.hazelcast.util.executor.DelegatingFuture
-  
- isCheckClassDefErrors() - Method in class com.hazelcast.config.SerializationConfig
- 
Default value is true (enabled). 
- isClaimingMaster() - Method in class com.hazelcast.cluster.impl.TcpIpJoiner
-  
- isClassAvailable(ClassLoader, String) - Static method in class com.hazelcast.nio.ClassLoaderUtil
-  
- isClassDefined(String) - Static method in class com.hazelcast.nio.ClassLoaderUtil
- 
Indicates whether or not the given class exists 
- isClient() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- isClient() - Method in interface com.hazelcast.nio.Connection
- 
Checks if it is a client connection. 
- isClient() - Method in enum com.hazelcast.nio.ConnectionType
-  
- isClient() - Method in interface com.hazelcast.nio.IOService
-  
- isClient() - Method in class com.hazelcast.nio.NodeIOService
-  
- isClient() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- isClosed() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- isClusterSafe() - Method in class com.hazelcast.client.proxy.PartitionServiceProxy
-  
- isClusterSafe() - Method in interface com.hazelcast.core.PartitionService
- 
Checks whether the cluster is in a safe state. 
- isClusterSafe() - Method in class com.hazelcast.jmx.PartitionServiceMBean
-  
- isClusterSafe() - Method in class com.hazelcast.partition.PartitionServiceProxy
-  
- isCoalesce() - Method in class com.hazelcast.config.QueryCacheConfig
- 
Returns trueif coalescing is is enabled, otherwise returnsfalse.
 
- isCommunicateStats() - Method in class com.hazelcast.config.JobTrackerConfig
- 
True if statistics (for example, about processed entries)
 are transmitted to the job emitter, false otherwise. 
- isCommunicateStats() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-  
- isCompatible(ConfigCheck) - Method in class com.hazelcast.cluster.impl.ConfigCheck
- 
Checks if two Hazelcast configurations are compatible. 
- isCompatible(Config) - Method in class com.hazelcast.config.Config
-  
- isCompatible(MapConfig) - Method in class com.hazelcast.config.MapConfig
-  
- isComplete() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
- 
Checks the frame size and total data size to validate the message size. 
- isConcurrent() - Method in class com.hazelcast.hibernate.serialization.ExpiryMarker
-  
- isConfigurableService() - Method in class com.hazelcast.spi.impl.servicemanager.ServiceInfo
-  
- isConnected() - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
-  
- isConnected() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
- 
Returns if this member is connected to the Wan publisher 
- isConnected() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-  
- isConnected() - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-  
- isConnectionTracingDetail() - Method in class com.hazelcast.jca.ManagedConnectionFactoryImpl
- 
Getter for the RAR property 'connectionTracingDetails' 
- isCoreService() - Method in class com.hazelcast.spi.impl.servicemanager.ServiceInfo
-  
- isData(byte) - Static method in class com.hazelcast.util.Base64
-  
- isDefaultClassLoader - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- isDefaultURI - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- isDeliverClosed() - Method in class com.hazelcast.jca.ManagedConnectionImpl
-  
- isDeliverCommitedEvent() - Method in class com.hazelcast.jca.ManagedConnectionImpl
-  
- isDeliverRolledback() - Method in class com.hazelcast.jca.ManagedConnectionImpl
-  
- isDeliverStartedEvent() - Method in class com.hazelcast.jca.ManagedConnectionImpl
-  
- isDestroy() - Method in class com.hazelcast.cache.impl.CacheDistributedObject
-  
- isDestroyed() - Method in interface com.hazelcast.cache.ICache
- 
Determines whether this Cache instance has been destroyed. 
- isDirty() - Method in class com.hazelcast.web.LocalCacheEntry
- 
Is dirty. 
- isDone() - Method in class com.hazelcast.client.spi.impl.ClientInvocationFuture
-  
- isDone() - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-  
- isDone() - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-  
- isDone() - Method in class com.hazelcast.util.executor.CompletedFuture
-  
- isDone() - Method in class com.hazelcast.util.executor.DelegatingFuture
-  
- ISemaphore - Interface in com.hazelcast.core
- 
ISemaphore is a backed-up distributed alternative to the  Semaphore. 
- isEmpty() - Method in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
-  
- isEmpty() - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
-  
- isEmpty() - Method in class com.hazelcast.client.proxy.ClientListProxy
-  
- isEmpty() - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- isEmpty() - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-  
- isEmpty() - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-  
- isEmpty() - Method in class com.hazelcast.client.proxy.ClientSetProxy
-  
- isEmpty() - Method in class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-  
- isEmpty() - Method in class com.hazelcast.client.txn.proxy.ClientTxnMapProxy
-  
- isEmpty() - Method in class com.hazelcast.cluster.impl.MemberSelectingCollection
-  
- isEmpty() - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-  
- isEmpty() - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
-  
- isEmpty() - Method in interface com.hazelcast.core.BaseMap
- 
Returns true if this map contains no entries. 
- isEmpty() - Method in interface com.hazelcast.core.TransactionalMap
- 
- isEmpty() - Method in class com.hazelcast.map.impl.MapEntries
-  
- isEmpty() - Method in class com.hazelcast.map.impl.operation.MapReplicationOperation
-  
- isEmpty() - Method in class com.hazelcast.map.impl.query.QueryResult
-  
- isEmpty() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- isEmpty() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- isEmpty() - Method in interface com.hazelcast.map.impl.recordstore.Storage
-  
- isEmpty() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-  
- isEmpty() - Method in interface com.hazelcast.map.QueryCache
-  
- isEmpty() - Method in class com.hazelcast.query.impl.getters.MultiResult
-  
- isEmpty() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicationOperation
-  
- isEmpty() - Method in class com.hazelcast.replicatedmap.impl.PartitionContainer
-  
- isEmpty() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-  
- isEmpty() - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
-  
- isEmpty() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- isEmpty() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-  
- isEmpty() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-  
- isEmpty() - Method in class com.hazelcast.util.collection.BiInt2ObjectMap
- 
Is map empty or not. 
- isEmpty() - Method in class com.hazelcast.util.collection.InflatableSet
-  
- isEmpty() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
- isEmpty() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
-  
- isEmpty() - Method in class com.hazelcast.util.collection.IntHashSet
- isEmpty() - Method in class com.hazelcast.util.collection.Long2LongHashMap
- isEmpty() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
- isEmpty() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
-  
- isEmpty() - Method in class com.hazelcast.util.collection.LongHashSet
- isEmpty() - Method in class com.hazelcast.util.collection.MapDelegatingSet
- isEmpty(Collection) - Static method in class com.hazelcast.util.CollectionUtil
- 
Returns trueif the given collection is null or empty, otherwise returnsfalse.
 
- isEmpty() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
- 
Returns true if this map contains no key-value mappings. 
- IsEmptyOperation - Class in com.hazelcast.collection.impl.queue.operations
- 
check if queue is empty 
- IsEmptyOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.IsEmptyOperation
-  
- IsEmptyOperation(String) - Constructor for class com.hazelcast.collection.impl.queue.operations.IsEmptyOperation
-  
- IsEmptyOperation - Class in com.hazelcast.replicatedmap.impl.operation
-  
- IsEmptyOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.IsEmptyOperation
-  
- IsEmptyOperation(String) - Constructor for class com.hazelcast.replicatedmap.impl.operation.IsEmptyOperation
-  
- IsEmptyOperationFactory - Class in com.hazelcast.map.impl.operation
-  
- IsEmptyOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.IsEmptyOperationFactory
-  
- IsEmptyOperationFactory(String) - Constructor for class com.hazelcast.map.impl.operation.IsEmptyOperationFactory
-  
- IsEmptyRequest - Class in com.hazelcast.collection.impl.queue.client
- 
Request to check if the Queue is empty 
- IsEmptyRequest() - Constructor for class com.hazelcast.collection.impl.queue.client.IsEmptyRequest
-  
- IsEmptyRequest(String) - Constructor for class com.hazelcast.collection.impl.queue.client.IsEmptyRequest
-  
- isEnableCompression() - Method in class com.hazelcast.config.SerializationConfig
- 
Enables compression when default java serialization is used. 
- isEnabled() - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
-  
- isEnabled() - Method in class com.hazelcast.config.AwsConfig
- 
Checks if the aws join mechanism is enabled. 
- isEnabled() - Method in class com.hazelcast.config.DiscoveryConfig
-  
- isEnabled() - Method in class com.hazelcast.config.HotRestartConfig
- 
Returns whether hot restart enabled on related data structure. 
- isEnabled() - Method in class com.hazelcast.config.HotRestartPersistenceConfig
- 
Returns whether hot restart enabled on this member. 
- isEnabled() - Method in class com.hazelcast.config.InterfacesConfig
-  
- isEnabled() - Method in class com.hazelcast.config.ManagementCenterConfig
- 
True if management center is enabled, false if disabled. 
- isEnabled() - Method in class com.hazelcast.config.MapStoreConfig
- 
Returns if this configuration is enabled 
- isEnabled() - Method in class com.hazelcast.config.MulticastConfig
- 
Check if the multicast discovery mechanism has been enabled. 
- isEnabled() - Method in class com.hazelcast.config.NativeMemoryConfig
-  
- isEnabled() - Method in class com.hazelcast.config.PartitionGroupConfig
- 
Checks if this PartitionGroupConfig is enabled. 
- isEnabled() - Method in class com.hazelcast.config.QueueStoreConfig
-  
- isEnabled() - Method in class com.hazelcast.config.QuorumConfig
-  
- isEnabled() - Method in class com.hazelcast.config.SecurityConfig
-  
- isEnabled() - Method in class com.hazelcast.config.ServiceConfig
-  
- isEnabled() - Method in class com.hazelcast.config.SocketInterceptorConfig
- 
Returns if this configuration is enabled 
- isEnabled() - Method in class com.hazelcast.config.SSLConfig
- 
Returns if this configuration is enabled. 
- isEnabled() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-  
- isEnabled() - Method in class com.hazelcast.config.TcpIpConfig
- 
Checks if the Tcp/Ip join mechanism is enabled. 
- isEnabled(ProbeLevel) - Method in enum com.hazelcast.internal.metrics.ProbeLevel
- 
Checks if the this ProbeLevel has a precedence equal or higher than the minimumLevel. 
- isEnableDefaults() - Method in class com.hazelcast.config.ServicesConfig
-  
- isEnableSharedObject() - Method in class com.hazelcast.config.SerializationConfig
- 
Default value is true. 
- isEnterprise() - Method in class com.hazelcast.instance.BuildInfo
-  
- isEquals(Object, Object) - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
-  
- isEquals(Object, Object) - Method in class com.hazelcast.map.impl.record.DataRecordFactory
-  
- isEquals(Object, Object) - Method in class com.hazelcast.map.impl.record.ObjectRecordFactory
-  
- isEquals(Object, Object) - Method in interface com.hazelcast.map.impl.record.RecordFactory
-  
- isEquals(Object, Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-  
- isError() - Method in class com.hazelcast.client.impl.client.ClientResponse
-  
- ISet<E> - Interface in com.hazelcast.core
- 
Concurrent, distributed implementation of  SetThis class is not a general-purpose Set implementation! While this class implements
 the Set interface, it intentionally violates Set's general contract, which mandates the
 use of the equals method when comparing objects.
- isEventsEnabled() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- isEvictable() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- isEvictionEnabled() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- isEvictionEnabled() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- isEvictionEnabled() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- isEvictionRequired() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore.MaxSizeEvictionChecker
-  
- isEvictionRequired() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore.MaxSizeEvictionChecker
-  
- isEvictionRequired() - Method in interface com.hazelcast.internal.eviction.EvictionChecker
- 
Checks for if eviction is required or not. 
- isExpirable() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- isExpirationAvailable() - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache
-  
- isExpired(E) - Method in interface com.hazelcast.internal.eviction.ExpirationChecker
- 
Checks if the given  Expirable entry is expired or not. 
- isExpired(long, long) - Method in class com.hazelcast.map.impl.nearcache.NearCacheRecord
-  
- isExpired(R, long, boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
- 
Checks whether a record is expired or not. 
- isExpiredAt(long) - Method in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-  
- isExpiredAt(long) - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-  
- isExpiredAt(long, long) - Static method in class com.hazelcast.cache.impl.record.CacheRecordFactory
- 
Determines whether the Cache Entry associated with this value will expire
 at the specified time. 
- isExpiredAt(long) - Method in interface com.hazelcast.internal.eviction.Expirable
- 
Checks whether the expiration time is passed with respect to the provided time. 
- isExplicitVersionCheckEnabled(Properties) - Static method in class com.hazelcast.hibernate.CacheEnvironment
-  
- isFineEnabled() - Method in class com.hazelcast.logging.AbstractLogger
-  
- isFineEnabled() - Method in interface com.hazelcast.logging.ILogger
- 
- isFinestEnabled() - Method in class com.hazelcast.logging.AbstractLogger
-  
- isFinestEnabled() - Method in interface com.hazelcast.logging.ILogger
- 
- isFirstConnection() - Method in interface com.hazelcast.client.ClientEndpoint
-  
- isFirstConnection() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- isFlagSet(short) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
-  
- isFsync() - Method in class com.hazelcast.config.HotRestartConfig
- 
Returns whether disk write should be followed by an fsync()system call.
 
- isGlobalOrderingEnabled() - Method in class com.hazelcast.config.TopicConfig
- 
Checks if global ordering is enabled (all nodes listening to the same topic
 get their messages in the same order), or disabled (nodes get
 the messages in the order that the messages are published). 
- isHeaderSet(int) - Method in class com.hazelcast.nio.Packet
-  
- isHeartBeating() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- isIdleAt(long, long) - Method in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-  
- isIdleAt(long, long) - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheRecord
- 
Checks whether the maximum idle time is passed with respect to the provided time
 without any access during this time period as maxIdleSeconds.
 
- isIncludeValue() - Method in class com.hazelcast.collection.impl.collection.CollectionEventFilter
-  
- isIncludeValue() - Method in class com.hazelcast.collection.impl.queue.QueueEventFilter
-  
- isIncludeValue() - Method in class com.hazelcast.config.EntryListenerConfig
-  
- isIncludeValue() - Method in class com.hazelcast.config.ItemListenerConfig
-  
- isIncludeValue() - Method in class com.hazelcast.config.ListenerConfig
-  
- isIncludeValue() - Method in class com.hazelcast.config.QueryCacheConfig
- 
Returns trueif value caching enabled, otherwise returnsfalse.
 
- isIncludeValue() - Method in class com.hazelcast.config.QuorumListenerConfig
-  
- isIncludeValue() - Method in class com.hazelcast.map.impl.EntryEventFilter
-  
- isIncludeValue(EventFilter) - Method in class com.hazelcast.map.impl.event.MapEventPublisherImpl
-  
- isIncludeValue() - Method in class com.hazelcast.multimap.impl.MultiMapEventFilter
-  
- isIndexed(QueryContext) - Method in class com.hazelcast.query.impl.FalsePredicate
-  
- isIndexed(QueryContext) - Method in class com.hazelcast.query.impl.predicates.AbstractIndexAwarePredicate
-  
- isIndexed(QueryContext) - Method in class com.hazelcast.query.impl.predicates.AndPredicate
-  
- isIndexed(QueryContext) - Method in class com.hazelcast.query.impl.predicates.NotEqualPredicate
-  
- isIndexed(QueryContext) - Method in class com.hazelcast.query.impl.predicates.OrPredicate
-  
- isIndexed(QueryContext) - Method in interface com.hazelcast.query.IndexAwarePredicate
-  
- isIndexed(QueryContext) - Method in class com.hazelcast.query.PagingPredicate
- 
- isIndexed(QueryContext) - Method in class com.hazelcast.query.PredicateBuilder
-  
- isIndexed(QueryContext) - Method in class com.hazelcast.query.SqlPredicate
-  
- isInitialized() - Method in class com.hazelcast.quorum.impl.QuorumImpl
-  
- isInsideAws() - Method in class com.hazelcast.client.config.ClientAwsConfig
- 
If client is inside aws, it will use private ip addresses directly,
 otherwise it will convert private ip addresses to public addresses
 internally by calling AWS API. 
- isInstanceOf(Class) - Method in class com.hazelcast.spi.impl.servicemanager.ServiceInfo
-  
- isInternalType(Class) - Static method in class com.hazelcast.nio.ClassLoaderUtil
-  
- isInvalidateOnChange() - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache
-  
- isInvalidateOnChange() - Method in interface com.hazelcast.cache.impl.nearcache.NearCache
-  
- isInvalidateOnChange() - Method in class com.hazelcast.client.map.impl.nearcache.ClientHeapNearCache
-  
- isInvalidateOnChange() - Method in class com.hazelcast.config.NearCacheConfig
- 
True to evict the cached entries if the entries are changed (updated or removed). 
- isInvalidateOnChange() - Method in class com.hazelcast.map.impl.nearcache.NearCacheImpl
-  
- isInvalidationEnabled() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- isInvalidationEnabled() - Method in class com.hazelcast.map.impl.MapContainer
-  
- isInvocationAllowedFromCurrentThread(Operation, boolean) - Method in class com.hazelcast.spi.impl.operationexecutor.classic.ClassicOperationExecutor
-  
- isInvocationAllowedFromCurrentThread(Operation, boolean) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
- 
Checks this operation can be invoked from the current thread. 
- isIpAddress(String) - Static method in class com.hazelcast.util.AddressUtil
-  
- isIPv4() - Method in class com.hazelcast.nio.Address
-  
- isIPv4() - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
-  
- isIPv6() - Method in class com.hazelcast.nio.Address
-  
- isIPv6() - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
-  
- isJcacheAvailable(ClassLoader) - Static method in class com.hazelcast.cache.impl.JCacheDetector
-  
- isJcacheAvailable(ClassLoader, ILogger) - Static method in class com.hazelcast.cache.impl.JCacheDetector
-  
- isJoinInProgress() - Method in class com.hazelcast.cluster.impl.ClusterJoinManager
-  
- isJoinOperation(Operation) - Static method in class com.hazelcast.spi.impl.operationutil.Operations
-  
- isKeepAlive() - Method in class com.hazelcast.client.config.SocketOptions
- 
SO_KEEPALIVE socket option 
- isKeyAndValueLoadable(Data, Object) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- isLiteMember() - Method in class com.hazelcast.cluster.impl.JoinMessage
-  
- isLiteMember() - Method in class com.hazelcast.cluster.MemberInfo
-  
- isLiteMember() - Method in class com.hazelcast.config.Config
-  
- isLiteMember() - Method in interface com.hazelcast.core.Member
- 
Returns true if this member is a lite member. 
- isLiteMember() - Method in class com.hazelcast.instance.AbstractMember
-  
- isLiteMember() - Method in class com.hazelcast.instance.Node
-  
- isLive() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- isLive() - Method in class com.hazelcast.util.executor.StripedExecutor
- 
Checks if this StripedExecutor is alive (so not shut down). 
- isLoaded() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- isLoaded() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- isLoaded - Variable in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-  
- isLoaded() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-  
- isLoaded() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- isLocal() - Method in class com.hazelcast.config.EntryListenerConfig
-  
- isLocal() - Method in class com.hazelcast.config.ListenerConfig
-  
- isLocal() - Method in class com.hazelcast.config.QuorumListenerConfig
-  
- isLocal() - Method in interface com.hazelcast.partition.InternalPartition
- 
Checks if the partition is local. 
- isLocal() - Method in class com.hazelcast.spi.impl.operationservice.impl.RemoteInvocationResponseHandler
-  
- isLocal() - Method in interface com.hazelcast.spi.OperationResponseHandler
- 
Checks if this OperationResponseHandler is for a local invocation. 
- isLocal() - Method in interface com.hazelcast.spi.ResponseHandler
- 
Deprecated. 
- isLocalMemberSafe() - Method in class com.hazelcast.client.proxy.PartitionServiceProxy
-  
- isLocalMemberSafe() - Method in interface com.hazelcast.core.PartitionService
- 
Check if the local member is safe to shutdown, meaning check if at least one backup of the partitions
 owned by the local member are in sync with primary. 
- isLocalMemberSafe() - Method in class com.hazelcast.jmx.PartitionServiceMBean
-  
- isLocalMemberSafe() - Method in class com.hazelcast.partition.PartitionServiceProxy
-  
- isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapAddEntryListenerMessageTask
-  
- isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerMessageTask
-  
- isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyMessageTask
-  
- isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyWithPredicateMessageTask
-  
- isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerWithPredicateMessageTask
-  
- isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddNearCacheEntryListenerMessageTask
-  
- isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.multimap.AbstractMultiMapAddEntryListenerMessageTask
-  
- isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerMessageTask
-  
- isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerToKeyMessageTask
-  
- isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
-  
- isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerMessageTask
-  
- isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyMessageTask
-  
- isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask
-  
- isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerWithPredicateMessageTask
-  
- isLocalOnly() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddNearCacheListenerMessageTask
-  
- isLocalOnly() - Method in interface com.hazelcast.spi.EventRegistration
- 
Returns true if this registration is for locally fired events only. 
- isLocalOnly() - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
-  
- isLocked() - Method in class com.hazelcast.client.proxy.ClientLockProxy
-  
- isLocked(K) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- isLocked(K) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-  
- isLocked() - Method in class com.hazelcast.concurrent.lock.LockProxy
-  
- isLocked(NodeEngine, Data) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
-  
- isLocked() - Method in interface com.hazelcast.concurrent.lock.LockResource
-  
- isLocked(Data) - Method in interface com.hazelcast.concurrent.lock.LockStore
-  
- isLocked(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- isLocked(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
-  
- isLocked() - Method in interface com.hazelcast.core.ILock
- 
Returns whether this lock is locked or not. 
- isLocked(K) - Method in interface com.hazelcast.core.IMap
- 
Checks the lock for the specified key. 
- isLocked(K) - Method in interface com.hazelcast.core.MultiMap
- 
Checks the lock for the specified key. 
- isLocked(Data, RecordStore) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
- 
Return 1 if locked, otherwise 0. 
- isLocked(K) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- isLocked(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- isLocked(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- isLocked(Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-  
- isLocked(K) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-  
- isLockedBy(String, long) - Method in interface com.hazelcast.concurrent.lock.LockResource
-  
- isLockedBy(Data, String, long) - Method in interface com.hazelcast.concurrent.lock.LockStore
-  
- isLockedBy(Data, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- isLockedBy(Data, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
-  
- isLockedByCurrentThread() - Method in class com.hazelcast.client.proxy.ClientLockProxy
-  
- isLockedByCurrentThread() - Method in class com.hazelcast.concurrent.lock.LockProxy
-  
- isLockedByCurrentThread(NodeEngine, Data) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
-  
- isLockedByCurrentThread() - Method in interface com.hazelcast.core.ILock
- 
Returns whether this lock is locked by current thread or not. 
- IsLockedOperation - Class in com.hazelcast.concurrent.lock.operations
-  
- IsLockedOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.IsLockedOperation
-  
- IsLockedOperation(ObjectNamespace, Data) - Constructor for class com.hazelcast.concurrent.lock.operations.IsLockedOperation
-  
- IsLockedOperation(ObjectNamespace, Data, long) - Constructor for class com.hazelcast.concurrent.lock.operations.IsLockedOperation
-  
- IsLockedRequest - Class in com.hazelcast.concurrent.lock.client
-  
- IsLockedRequest() - Constructor for class com.hazelcast.concurrent.lock.client.IsLockedRequest
-  
- IsLockedRequest(Data) - Constructor for class com.hazelcast.concurrent.lock.client.IsLockedRequest
-  
- IsLockedRequest(Data, long) - Constructor for class com.hazelcast.concurrent.lock.client.IsLockedRequest
-  
- isLoggable(Level) - Method in interface com.hazelcast.logging.ILogger
- 
Checks if a message at the provided level is going to be logged by this logger. 
- isLoopbackModeEnabled() - Method in class com.hazelcast.config.MulticastConfig
- 
Check if the loopback mode is enabled in the multicast discovery mechanism. 
- isLossTolerant() - Method in class com.hazelcast.topic.impl.reliable.ReliableMessageListenerAdapter
-  
- isLossTolerant() - Method in interface com.hazelcast.topic.ReliableMessageListener
- 
Checks if this ReliableMessageListener is able to deal with message loss. 
- isManagedService() - Method in class com.hazelcast.spi.impl.servicemanager.ServiceInfo
-  
- isManagementEnabled() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
-  
- isManagementEnabled() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Checks if management is enabled for this  ICache. 
- isMapLoader() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreContext
-  
- isMapLoader() - Method in class com.hazelcast.map.impl.MapStoreWrapper
-  
- isMaster() - Method in interface com.hazelcast.cluster.ClusterService
- 
Checks if this member is the master. 
- isMaster() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- isMaster() - Method in class com.hazelcast.instance.Node
-  
- isMaxSizeReached() - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
-  
- isMemberNearCacheInvalidationEnabled() - Method in class com.hazelcast.map.impl.MapContainer
-  
- isMemberNearCacheInvalidationEnabled(String) - Method in class com.hazelcast.map.impl.nearcache.AbstractNearCacheInvalidator
-  
- isMemberRemovedWhileClusterIsNotActive(Address) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- isMemberSafe(Member) - Method in class com.hazelcast.client.proxy.PartitionServiceProxy
-  
- isMemberSafe(Member) - Method in interface com.hazelcast.core.PartitionService
- 
Check if the given member is safe to shutdown, meaning check if at least one backup of the partitions
 owned by the given member are in sync with primary. 
- isMemberSafe(Member) - Method in class com.hazelcast.partition.PartitionServiceProxy
-  
- isMemberStateSafe() - Method in class com.hazelcast.monitor.impl.MemberPartitionStateImpl
-  
- isMemberStateSafe() - Method in interface com.hazelcast.monitor.MemberPartitionState
- 
Returns whether member is safe for shutdown. 
- isMemberStateSafe() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- isMemberStateSafe() - Method in interface com.hazelcast.partition.InternalPartitionService
- 
Query and return if this member in a safe state or not. 
- isMemcacheEnabled() - Method in interface com.hazelcast.nio.IOService
-  
- isMemcacheEnabled() - Method in class com.hazelcast.nio.NodeIOService
-  
- isMigrating() - Method in interface com.hazelcast.partition.InternalPartition
- 
Checks if there currently is a migration going on in this partition. 
- isMigrationAllowed() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- isMigrationOperation(Operation) - Static method in class com.hazelcast.spi.impl.operationutil.Operations
-  
- isMinimalPutsEnabledByDefault() - Method in class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
-  
- isMinSizeReached() - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
-  
- isModified() - Method in class com.hazelcast.map.impl.LazyMapEntry
-  
- isModified() - Method in class com.hazelcast.map.impl.MapEntrySimple
-  
- isNativeClient(Properties) - Static method in class com.hazelcast.hibernate.CacheEnvironment
-  
- isNearCacheEnabled() - Method in class com.hazelcast.config.MapConfig
- 
Checks if near cache is enabled 
- isNew() - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- isNodeInsideRegions(NodeMetadata) - Method in class com.hazelcast.jclouds.ComputeServiceBuilder
-  
- isNodeInsideZones(NodeMetadata) - Method in class com.hazelcast.jclouds.ComputeServiceBuilder
-  
- isNot(String) - Method in class com.hazelcast.query.EntryObject
-  
- isNotEmpty(Collection) - Static method in class com.hazelcast.util.CollectionUtil
- 
Returns trueif the given collection is not null and not empty, otherwise returnsfalse.
 
- isNotNull() - Method in class com.hazelcast.query.EntryObject
-  
- isNotNull(E, String) - Static method in class com.hazelcast.util.Preconditions
- 
Tests if a string is not null. 
- isNull() - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-  
- isNull() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceContainer
-  
- isNull() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- isNull() - Method in interface com.hazelcast.core.IAtomicReference
- 
Checks if the stored reference is null. 
- isNull() - Method in class com.hazelcast.query.EntryObject
-  
- IsNullOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-  
- IsNullOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.IsNullOperation
-  
- IsNullOperation(String) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.IsNullOperation
-  
- isNullOrEmpty(String) - Static method in class com.hazelcast.util.StringUtil
- 
Checks if a string is empty or not. 
- isNullOrEmptyAfterTrim(String) - Static method in class com.hazelcast.util.StringUtil
- 
Checks if a string is empty or not after trim operation 
- IsNullRequest - Class in com.hazelcast.concurrent.atomicreference.client
-  
- IsNullRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.IsNullRequest
-  
- IsNullRequest(String) - Constructor for class com.hazelcast.concurrent.atomicreference.client.IsNullRequest
-  
- ISO_8859_1 - Static variable in class com.hazelcast.nio.Bits
- 
A reusable instance of the ISO Latin-1 charset 
- isOldValueAvailable() - Method in class com.hazelcast.cache.impl.CacheEntryEventImpl
-  
- isOldValueAvailable() - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- isOldValueAvailable() - Method in interface com.hazelcast.cache.impl.CacheEventData
- 
Returns true if old value is available. 
- isOldValueAvailable() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-  
- isOldValueRequired() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
- 
If old value is required, previously assigned values for the affected keys
 will be sent to this cache entry listener implementation. 
- isOpen() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-  
- isOpen() - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-  
- isOperationExecuting(Address, String, Object) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-  
- isOperationExecuting(Address, String, Object) - Method in interface com.hazelcast.spi.ExecutionTracingService
-  
- isOperationExecuting(Invocation) - Method in class com.hazelcast.spi.impl.operationservice.impl.IsStillRunningService
- 
Checks if an operation is still running. 
- isOperationExecuting(Address, String, String, Object) - Method in class com.hazelcast.spi.impl.operationservice.impl.IsStillRunningService
- 
Checks if an operation is still running. 
- isOperationExecuting(Address, int, long) - Method in class com.hazelcast.spi.impl.operationservice.impl.IsStillRunningService
- 
Checks if an operation is still running. 
- isOperationThread() - Method in class com.hazelcast.spi.impl.operationexecutor.classic.ClassicOperationExecutor
-  
- isOperationThread() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
- 
Deprecated.
it should not matter if a thread is an operation thread or not; this is something operationExecutor specific. 
 
- isOptimizeQueries() - Method in class com.hazelcast.config.MapConfig
- 
- isOrdered() - Method in class com.hazelcast.config.MapIndexConfig
- 
Checks if the index should be ordered. 
- isOrdered() - Method in interface com.hazelcast.query.impl.Index
-  
- isOrdered() - Method in class com.hazelcast.query.impl.IndexImpl
-  
- isOriginatedFromClient() - Method in interface com.hazelcast.transaction.impl.Transaction
-  
- isOriginatedFromClient() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-  
- isOriginatedFromClient() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
-  
- isOverrideJavaSerialization() - Method in class com.hazelcast.config.GlobalSerializerConfig
-  
- isOverwritable() - Method in class com.hazelcast.hibernate.serialization.Hibernate3CacheEntrySerializerHook
-  
- isOverwritable() - Method in class com.hazelcast.hibernate.serialization.Hibernate3CacheKeySerializerHook
-  
- isOverwritable() - Method in class com.hazelcast.hibernate.serialization.Hibernate4CacheEntrySerializerHook
-  
- isOverwritable() - Method in class com.hazelcast.hibernate.serialization.Hibernate4CacheKeySerializerHook
-  
- isOverwritable() - Method in interface com.hazelcast.nio.serialization.SerializerHook
- 
Defines if this serializer can be overridden by defining a custom
 serializer in the configurations (codebase or configuration file) 
- isOwn(Data) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- isOwnerConnection() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
-  
- isOwnerConnection() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationCustomCredentialsMessageTask
-  
- isOwnerConnection() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationMessageTask
-  
- isOwnerNode() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-  
- isOwnerOrBackup(int) - Method in class com.hazelcast.map.impl.eviction.EvictionCheckerImpl
-  
- isOwnerOrBackup(Address) - Method in interface com.hazelcast.partition.InternalPartition
- 
Checks if given address is owner of primary or backup of this partition. 
- isPad(byte) - Static method in class com.hazelcast.util.Base64
-  
- isPartitionOwner(int) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- isPartitionOwner(int) - Method in interface com.hazelcast.partition.InternalPartitionService
- 
Check if this node is the owner of a  partition 
- isPartitionReplicaVersionStale(int, long[], int) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- isPartitionReplicaVersionStale(int, long[], int) - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- isPaused() - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
-  
- isPaused() - Method in interface com.hazelcast.monitor.LocalWanPublisherStats
- 
Returns if the wan replication on this member is paused 
- isPollOperation() - Method in class com.hazelcast.collection.impl.txnqueue.TxQueueItem
-  
- isPopulate() - Method in class com.hazelcast.config.QueryCacheConfig
- 
Returns trueif initial population ofQueryCacheis enabled, otherwise returnsfalse.
 
- isPortable() - Method in class com.hazelcast.internal.serialization.impl.HeapData
-  
- isPortable() - Method in interface com.hazelcast.nio.serialization.Data
- 
Returns true if this Data is created from a  Portable object,
 false otherwise. 
- isPortAutoIncrement() - Method in class com.hazelcast.config.NetworkConfig
- 
Checks if a Hazelcast member is allowed find a free port by incrementing the port number when it encounters
 an occupied port. 
- isPostProcessing(RecordStore) - Method in class com.hazelcast.map.impl.operation.MapOperation
-  
- isPostProcessingMapStore() - Method in class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
-  
- isPostProcessingMapStore() - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
-  
- isPostProcessingMapStore() - Method in class com.hazelcast.map.impl.MapStoreWrapper
-  
- isPowerOfTwo(long) - Static method in class com.hazelcast.util.QuickMath
- 
Return true if input argument is power of two. 
- isPreCheckEnabled() - Method in class com.hazelcast.map.impl.query.QueryResultSizeLimiter
- 
Just for testing. 
- isPresent() - Method in class com.hazelcast.quorum.impl.QuorumImpl
-  
- isPresent() - Method in interface com.hazelcast.quorum.Quorum
- 
Returns true if quorum is present, false if absent. 
- isPresent() - Method in class com.hazelcast.quorum.QuorumEvent
- 
Returns the presence of the quorum 
- isProcessing() - Method in class com.hazelcast.partition.MigrationInfo
-  
- isQueryResultLimitEnabled() - Method in class com.hazelcast.map.impl.query.QueryResultSizeLimiter
- 
Just for testing. 
- isReachedToMaxSize() - Method in class com.hazelcast.cache.impl.maxsize.impl.EntryCountCacheMaxSizeChecker
-  
- isReachedToMaxSize() - Method in interface com.hazelcast.cache.impl.maxsize.MaxSizeChecker
- 
- isReachedToMaxSize() - Method in class com.hazelcast.cache.impl.nearcache.impl.maxsize.EntryCountNearCacheMaxSizeChecker
-  
- isReadBackupData() - Method in class com.hazelcast.config.MapConfig
- 
Checks if read-backup-data (reading local backup entires) is enabled for this map. 
- isReadThrough() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- isReadThrough() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
-  
- isReadThrough() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Checks if this  ICache is read-through: a read loads the entry from the data store
 if it is not already in the cache. 
- isRecordExpired(R) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- isRedoOperation() - Method in class com.hazelcast.client.config.ClientConfig
- 
Deprecated. 
- isRedoOperation() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-  
- isRedoOperation() - Method in interface com.hazelcast.client.spi.ClientInvocationService
-  
- isRegistered(String, String, boolean) - Static method in class com.hazelcast.cache.impl.MXBeanUtil
-  
- isReload() - Method in class com.hazelcast.web.LocalCacheEntry
- 
Is reload. 
- isRemoved() - Method in class com.hazelcast.web.LocalCacheEntry
- 
Is removed. 
- isRemoveOperation() - Method in class com.hazelcast.collection.impl.collection.TxCollectionItem
-  
- isReplaceableBy(long, Object, Comparator) - Method in class com.hazelcast.hibernate.serialization.Expirable
- 
Determine if the current entry can be overridden with a value corresponding to the given new version
 and the transaction timestamp. 
- isReplaceableBy(long, Object, Comparator) - Method in class com.hazelcast.hibernate.serialization.ExpiryMarker
-  
- isReplaceableBy(long, Object, Comparator) - Method in class com.hazelcast.hibernate.serialization.Value
-  
- isReplicaAvailable(Address, InternalPartitionService, int) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
-  
- isReplicaOnThisNode(Address, Address) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
-  
- isReplicaSyncAllowed() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- IsReplicaVersionSync - Class in com.hazelcast.partition.impl
- 
Queries if replica version is sync between partitions. 
- IsReplicaVersionSync() - Constructor for class com.hazelcast.partition.impl.IsReplicaVersionSync
-  
- IsReplicaVersionSync(long) - Constructor for class com.hazelcast.partition.impl.IsReplicaVersionSync
-  
- isRepublishingEnabled() - Method in class com.hazelcast.config.WanReplicationRef
-  
- isRestEnabled() - Method in interface com.hazelcast.nio.IOService
-  
- isRestEnabled() - Method in class com.hazelcast.nio.NodeIOService
-  
- isResultDeserialized() - Method in class com.hazelcast.spi.InvocationBuilder
- 
Checks if the Future should automatically deserialize the result. 
- isRetryable() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
-  
- isRetryable(Throwable) - Static method in class com.hazelcast.client.spi.impl.ClientInvocation
-  
- isReuseAddress() - Method in class com.hazelcast.client.config.SocketOptions
- 
SO_REUSEADDR socket option. 
- isReuseAddress() - Method in class com.hazelcast.config.NetworkConfig
-  
- isRunning() - Method in class com.hazelcast.client.impl.LifecycleServiceImpl
-  
- isRunning() - Method in interface com.hazelcast.core.LifecycleService
- 
checks whether or not the instance is running 
- isRunning() - Method in class com.hazelcast.instance.LifecycleServiceImpl
-  
- isRunning() - Method in class com.hazelcast.instance.Node
- 
Indicates that node is not shutting down or it has not already shut down 
- isRunning() - Method in class com.hazelcast.instance.TerminatedLifecycleService
-  
- isRunning() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- isRunning() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- isRunning() - Method in interface com.hazelcast.spi.NodeEngine
- 
Indicates that node is not shutting down or it has not already shut down 
- isSameGroup(ConfigCheck) - Method in class com.hazelcast.cluster.impl.ConfigCheck
-  
- isSameRM(XAResource) - Method in class com.hazelcast.client.proxy.txn.xa.XAResourceProxy
-  
- isSameRM(XAResource) - Method in class com.hazelcast.client.txn.proxy.xa.XAResourceProxy
-  
- isSameRM(XAResource) - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
-  
- isShutdown() - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- isShutdown(String) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-  
- isShutdown() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- isShutdown() - Method in class com.hazelcast.jmx.ManagedExecutorServiceMBean
-  
- isShutdown() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-  
- IsShutdownRequest - Class in com.hazelcast.executor.impl.client
-  
- IsShutdownRequest() - Constructor for class com.hazelcast.executor.impl.client.IsShutdownRequest
-  
- IsShutdownRequest(String) - Constructor for class com.hazelcast.executor.impl.client.IsShutdownRequest
-  
- isSmartRouting() - Method in class com.hazelcast.client.config.ClientConfig
- 
Deprecated. 
- isSmartRouting() - Method in class com.hazelcast.client.config.ClientNetworkConfig
-  
- isSnapshotEnabled() - Method in class com.hazelcast.config.WanReplicationConfig
-  
- isSocketBind() - Method in interface com.hazelcast.nio.IOService
-  
- isSocketBind() - Method in class com.hazelcast.nio.NodeIOService
-  
- isSocketBindAny() - Method in interface com.hazelcast.nio.IOService
-  
- isSocketBindAny() - Method in class com.hazelcast.nio.NodeIOService
-  
- isSocketInterceptorEnabled() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- isSSlEnabled() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapperFactory
-  
- isSSlEnabled() - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapperFactory
-  
- isSSLEnabled() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- isStart() - Method in class com.hazelcast.internal.management.request.ChangeWanStateRequest
-  
- isStartCompleted() - Method in class com.hazelcast.instance.DefaultNodeExtension
-  
- isStartCompleted() - Method in interface com.hazelcast.instance.NodeExtension
- 
Returns true if the instance has started 
- isStatisticsEnabled() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- isStatisticsEnabled() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
-  
- isStatisticsEnabled() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Checks if statistics are enabled for this  ICache. 
- isStatisticsEnabled() - Method in class com.hazelcast.config.CollectionConfig
- 
Checks if collection statistics are enabled. 
- isStatisticsEnabled() - Method in class com.hazelcast.config.ExecutorConfig
- 
Gets if statistics gathering is enabled or disabled on the executor task. 
- isStatisticsEnabled() - Method in class com.hazelcast.config.MapConfig
- 
Checks if statistics are enabled for this map. 
- isStatisticsEnabled() - Method in class com.hazelcast.config.MultiMapConfig
- 
Checks to see if statistics are enabled for this MultiMap. 
- isStatisticsEnabled() - Method in class com.hazelcast.config.QueueConfig
- 
Check if statistics are enabled for this queue. 
- isStatisticsEnabled() - Method in class com.hazelcast.config.ReliableTopicConfig
- 
Checks if statistics are enabled for this reliable topic. 
- isStatisticsEnabled() - Method in class com.hazelcast.config.ReplicatedMapConfig
- 
Checks if statistics are enabled for this replicated map. 
- isStatisticsEnabled() - Method in class com.hazelcast.config.TopicConfig
- 
Checks if statistics are enabled for this topic. 
- isStickySession() - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- IsStillExecutingOperation - Class in com.hazelcast.spi.impl.operationservice.impl.operations
- 
An operation that checks if another operation is still running. 
- IsStillExecutingOperation() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.operations.IsStillExecutingOperation
-  
- IsStillExecutingOperation(long, int) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.operations.IsStillExecutingOperation
-  
- IsStillRunningService - Class in com.hazelcast.spi.impl.operationservice.impl
- 
Checks if an Operation is still running. 
- IsStillRunningService(OperationExecutor, NodeEngineImpl, ILogger) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.IsStillRunningService
-  
- isStoreByValue() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
-  
- isSuitableForCompare(Comparator<Map.Entry>, IterationType, Map.Entry) - Static method in class com.hazelcast.util.SortingUtil
-  
- isSupported(OptionalFeature) - Method in class com.hazelcast.cache.HazelcastCachingProvider
-  
- isSupported(OptionalFeature) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-  
- isSyncForced(BackupAwareOperation) - Method in class com.hazelcast.spi.impl.operationservice.impl.BackpressureRegulator
- 
Checks if a sync is forced for the given BackupAwareOperation. 
- isSynchronous() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
- 
If true, this cache entry listener implementation will be called
 in a synchronous manner. 
- isTcpNoDelay() - Method in class com.hazelcast.client.config.SocketOptions
- 
TCP_NODELAY socket option 
- isTerminal(Throwable) - Method in class com.hazelcast.topic.impl.reliable.ReliableMessageListenerAdapter
-  
- isTerminal(Throwable) - Method in interface com.hazelcast.topic.ReliableMessageListener
- 
- isTerminated() - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- isTerminated() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- isTerminated - Variable in class com.hazelcast.internal.management.dto.ManagedExecutorDTO
-  
- isTerminated() - Method in class com.hazelcast.jmx.ManagedExecutorServiceMBean
-  
- isTerminated() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-  
- isTombstone() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-  
- isTransactional() - Method in interface com.hazelcast.concurrent.lock.LockResource
-  
- isTransactionallyLocked(Data) - Method in interface com.hazelcast.concurrent.lock.LockStore
-  
- isTransactionallyLocked(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- isTransactionallyLocked(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
-  
- isTransactionallyLocked(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- isTransactionallyLocked(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- isTransactionallyLocked(Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-  
- isTransactionAware() - Method in class com.hazelcast.hibernate.region.AbstractTransactionalDataRegion
-  
- isTransient() - Method in class com.hazelcast.web.LocalCacheEntry
- 
Is transient. 
- isUrgent() - Method in class com.hazelcast.client.impl.protocol.ClientMessage
-  
- isUrgent() - Method in class com.hazelcast.client.spi.impl.ClientInvocation
-  
- isUrgent() - Method in class com.hazelcast.internal.ascii.AbstractTextCommand
-  
- isUrgent() - Method in interface com.hazelcast.nio.OutboundFrame
- 
Checks if this Frame is urgent. 
- isUrgent() - Method in class com.hazelcast.nio.Packet
-  
- isUrgent() - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
- 
Check if this Response is an urgent response. 
- isUrgent() - Method in class com.hazelcast.spi.Operation
-  
- isUseNativeByteOrder() - Method in class com.hazelcast.config.SerializationConfig
-  
- isValid() - Method in class com.hazelcast.cluster.impl.operations.MemberInfoUpdateOperation
-  
- isValid() - Method in class com.hazelcast.partition.MigrationInfo
-  
- isValid() - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- isValidForFetching(V, long) - Method in class com.hazelcast.util.SampleableConcurrentHashMap
-  
- isValidForSampling(V) - Method in class com.hazelcast.util.SampleableConcurrentHashMap
-  
- isWanReplicationEnabled() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- isWanReplicationEnabled(String) - Method in class com.hazelcast.cache.impl.CacheService
-  
- isWanReplicationEnabled() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Determines whether wan replication is enabled or not for this record store. 
- isWanReplicationEnabled(String) - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- isWanReplicationEnabled() - Method in class com.hazelcast.map.impl.MapContainer
-  
- isWanReplicationOperation(Operation) - Static method in class com.hazelcast.spi.impl.operationutil.Operations
- 
- isWhiteSpace(byte) - Static method in class com.hazelcast.util.Base64
-  
- isWriteBehindMapStoreEnabled() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreContext
-  
- isWriteCoalescing() - Method in class com.hazelcast.config.MapStoreConfig
- 
Returns trueif write-coalescing is enabled.
 
- isWriteThrough() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- isWriteThrough() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
-  
- isWriteThrough() - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Checks if the  ICache is write-through: a write to the queue also loads the entry
 into the data store. 
- item - Variable in class com.hazelcast.core.ItemEvent
-  
- ITEM_EVENT - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
-  
- itemAdded(ItemEvent) - Method in class com.hazelcast.client.console.ClientConsoleApp
-  
- itemAdded(ItemEvent) - Method in class com.hazelcast.console.ConsoleApp
-  
- itemAdded(ItemEvent<E>) - Method in interface com.hazelcast.core.ItemListener
- 
Invoked when an item is added. 
- ItemCounter<T> - Class in com.hazelcast.util
- 
Non Thread-Safe Counter of things. 
- ItemCounter() - Constructor for class com.hazelcast.util.ItemCounter
-  
- ItemEvent<E> - Class in com.hazelcast.core
- 
Map Item event. 
- ItemEvent(String, ItemEventType, E, Member) - Constructor for class com.hazelcast.core.ItemEvent
-  
- ItemEventType - Enum in com.hazelcast.core
- 
Type of item event. 
- itemId - Variable in class com.hazelcast.collection.impl.collection.CollectionItem
-  
- itemId - Variable in class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
-  
- itemId - Variable in class com.hazelcast.collection.impl.queue.QueueItem
-  
- itemIdSet - Variable in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
-  
- ItemListener<E> - Interface in com.hazelcast.core
- 
- ItemListenerConfig - Class in com.hazelcast.config
- 
Contains the configuration for an Item Listener. 
- ItemListenerConfig() - Constructor for class com.hazelcast.config.ItemListenerConfig
-  
- ItemListenerConfig(String, boolean) - Constructor for class com.hazelcast.config.ItemListenerConfig
-  
- ItemListenerConfig(ItemListener, boolean) - Constructor for class com.hazelcast.config.ItemListenerConfig
-  
- ItemListenerConfig(ItemListenerConfig) - Constructor for class com.hazelcast.config.ItemListenerConfig
-  
- ItemListenerConfigReadOnly - Class in com.hazelcast.config
- 
Contains the configuration for an Item Listener(Read-only). 
- ItemListenerConfigReadOnly(ItemListenerConfig) - Constructor for class com.hazelcast.config.ItemListenerConfigReadOnly
-  
- itemMap - Variable in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- itemRemoved(ItemEvent) - Method in class com.hazelcast.client.console.ClientConsoleApp
-  
- itemRemoved(ItemEvent) - Method in class com.hazelcast.console.ConsoleApp
-  
- itemRemoved(ItemEvent<E>) - Method in interface com.hazelcast.core.ItemListener
- 
Invoked when an item is removed. 
- IterableUtil - Class in com.hazelcast.util
- 
Utility functions for working with  Iterable
- ITERATE - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- iterateStats - Variable in class com.hazelcast.map.impl.LocalMapStatsProvider
-  
- IterationType - Enum in com.hazelcast.util
- 
To differentiate users selection on result collection on map-wide operations
 like values , keySet , query etc. 
- iterator(int, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- iterator() - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- iterator(int, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Starting from the provided table index, a set of keys are returned with a maximum size of size
 
- iterator() - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- iterator() - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
-  
- iterator() - Method in class com.hazelcast.client.proxy.ClientListProxy
-  
- iterator() - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-  
- iterator() - Method in class com.hazelcast.client.proxy.ClientSetProxy
-  
- iterator() - Method in class com.hazelcast.cluster.impl.MemberSelectingCollection
-  
- iterator() - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-  
- iterator() - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
-  
- ITERATOR - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-  
- ITERATOR - Static variable in class com.hazelcast.collection.impl.queue.QueuePortableHook
-  
- iterator() - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
-  
- iterator() - Method in class com.hazelcast.map.impl.MapEntries
-  
- iterator() - Method in class com.hazelcast.map.impl.query.QueryResult
-  
- iterator() - Method in class com.hazelcast.map.impl.query.QueryResultCollection
-  
- iterator() - Method in class com.hazelcast.map.impl.query.SortedQueryResultSet
-  
- iterator() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- iterator(long, boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- iterator() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
- 
Iterates over record store entries. 
- iterator(long, boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
- 
Iterates over record store entries by respecting expiration. 
- iterator() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
-  
- iterator() - Method in interface com.hazelcast.partition.membergroup.MemberGroup
-  
- iterator() - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
-  
- iterator() - Method in class com.hazelcast.query.impl.AndResultSet
-  
- iterator() - Method in class com.hazelcast.query.impl.DuplicateDetectingMultiResult
-  
- iterator() - Method in class com.hazelcast.query.impl.FastMultiResultSet
-  
- iterator() - Method in class com.hazelcast.query.impl.OrResultSet
-  
- iterator() - Method in class com.hazelcast.query.impl.SingleResultSet
-  
- iterator() - Method in class com.hazelcast.replicatedmap.impl.record.ResultSet
-  
- iterator() - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
-  
- iterator() - Method in class com.hazelcast.spi.impl.SerializableList
-  
- iterator() - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
-  
- iterator() - Method in class com.hazelcast.util.collection.InflatableSet
-  
- iterator() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
-  
- iterator() - Method in class com.hazelcast.util.collection.IntHashSet
- iterator() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
-  
- iterator() - Method in class com.hazelcast.util.collection.LongHashSet
- iterator() - Method in class com.hazelcast.util.collection.MapDelegatingSet
- iterator(Class<T>, String, ClassLoader) - Static method in class com.hazelcast.util.ServiceLoader
-  
- IteratorOperation - Class in com.hazelcast.collection.impl.queue.operations
- 
Provides iterator functionality for Queue. 
- IteratorOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.IteratorOperation
-  
- IteratorOperation(String) - Constructor for class com.hazelcast.collection.impl.queue.operations.IteratorOperation
-  
- IteratorRequest - Class in com.hazelcast.collection.impl.queue.client
- 
- IteratorRequest() - Constructor for class com.hazelcast.collection.impl.queue.client.IteratorRequest
-  
- IteratorRequest(String) - Constructor for class com.hazelcast.collection.impl.queue.client.IteratorRequest
-  
- ITopic<E> - Interface in com.hazelcast.core
- 
Hazelcast provides distribution mechanism for publishing messages that are delivered to multiple subscribers,
 which is also known as a publish/subscribe (pub/sub) messaging model. 
- main(String[]) - Static method in class com.hazelcast.client.console.ClientConsoleApp
- 
Starts the test application. 
- main(String[]) - Static method in class com.hazelcast.console.ConsoleApp
- 
Starts the test application. 
- main(String[]) - Static method in class com.hazelcast.core.server.StartServer
- 
Creates a server instance of Hazelcast 
- ManagedAnnotation - Annotation Type in com.hazelcast.jmx
- 
Annotation for management bean attributes. 
- ManagedConnectionFactoryImpl - Class in com.hazelcast.jca
- 
This managed connection factory is populated with all
 container-specific configuration and infrastructure 
- ManagedConnectionFactoryImpl() - Constructor for class com.hazelcast.jca.ManagedConnectionFactoryImpl
-  
- ManagedConnectionImpl - Class in com.hazelcast.jca
- 
Implementation class of ManagedConnection
 
- ManagedConnectionImpl(ConnectionRequestInfo, ManagedConnectionFactoryImpl) - Constructor for class com.hazelcast.jca.ManagedConnectionImpl
-  
- ManagedContext - Interface in com.hazelcast.core
- 
Container managed context, such as Spring, Guice and etc. 
- managedContext - Variable in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- managedContext - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- ManagedDescription - Annotation Type in com.hazelcast.jmx
- 
Annotation for management bean descriptions. 
- ManagedExecutorDTO - Class in com.hazelcast.internal.management.dto
- 
- ManagedExecutorDTO() - Constructor for class com.hazelcast.internal.management.dto.ManagedExecutorDTO
-  
- ManagedExecutorDTO(ManagedExecutorService) - Constructor for class com.hazelcast.internal.management.dto.ManagedExecutorDTO
-  
- ManagedExecutorService - Interface in com.hazelcast.util.executor
-  
- ManagedExecutorServiceMBean - Class in com.hazelcast.jmx
- 
- ManagedExecutorServiceMBean(HazelcastInstance, ManagedExecutorService, ManagementService) - Constructor for class com.hazelcast.jmx.ManagedExecutorServiceMBean
-  
- managedService - Variable in class com.hazelcast.map.impl.MapService
-  
- ManagedService - Interface in com.hazelcast.spi
- 
A interface that can be implemented by a SPI Service to receive lifecycle calls:
 
     initialization
     shutdown
     reset
  
- MANAGEMENT_CONFIG - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- MANAGEMENT_CONFIG - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- ManagementCenterConfig - Class in com.hazelcast.config
- 
Contains the configuration for a Management Center. 
- ManagementCenterConfig() - Constructor for class com.hazelcast.config.ManagementCenterConfig
-  
- ManagementCenterConfig(String, int) - Constructor for class com.hazelcast.config.ManagementCenterConfig
-  
- ManagementCenterIdentifier - Class in com.hazelcast.internal.management
- 
Identifier for the ManagementCenter. 
- ManagementCenterIdentifier() - Constructor for class com.hazelcast.internal.management.ManagementCenterIdentifier
-  
- ManagementCenterIdentifier(String, String, String) - Constructor for class com.hazelcast.internal.management.ManagementCenterIdentifier
-  
- ManagementCenterService - Class in com.hazelcast.internal.management
- 
ManagementCenterService is responsible for sending statistics data to the Management Center. 
- ManagementCenterService(HazelcastInstanceImpl) - Constructor for class com.hazelcast.internal.management.ManagementCenterService
-  
- ManagementCenterService.MemberListenerImpl - Class in com.hazelcast.internal.management
- 
MembershipListener to send Management Center URL to the new members. 
- ManagementCenterService.MemberListenerImpl() - Constructor for class com.hazelcast.internal.management.ManagementCenterService.MemberListenerImpl
-  
- ManagementService - Class in com.hazelcast.jmx
- 
Service responsible for registering hazelcast management beans to the platform management bean server. 
- ManagementService(HazelcastInstanceImpl) - Constructor for class com.hazelcast.jmx.ManagementService
-  
- map(KeyIn, ValueIn, Context<KeyOut, ValueOut>) - Method in class com.hazelcast.mapreduce.LifecycleMapperAdapter
- 
The map method is called for every single key-value pair in the bound  KeyValueSource instance
 on this cluster node and partition. 
 Due to its nature of a DataGrid, Hazelcast distributes values all over the cluster and so this method
 is executed on multiple servers at the same time. 
 If you want to know more about the implementation of MapReduce algorithms read the  Google Whitepaper on MapReduce. 
- map(KeyIn, ValueIn, Context<KeyOut, ValueOut>) - Method in interface com.hazelcast.mapreduce.Mapper
- 
The map method is called for every single key-value pair in the bound  KeyValueSource instance
 on this cluster node and partition. 
 Due to its nature of a DataGrid, Hazelcast distributes values all over the cluster and so this method
 is executed on multiple servers at the same time. 
 If you want to know more about the implementation of MapReduce algorithms read the  Google Whitepaper on MapReduce. 
- map(Iterable<T>, IFunction<T, R>) - Static method in class com.hazelcast.util.IterableUtil
- 
Transform the Iterable by applying a function to each element 
- map(Iterator<T>, IFunction<T, R>) - Static method in class com.hazelcast.util.IterableUtil
- 
Transform the Iterator by applying a function to each element 
- MAP_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- MAP_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- MAP_ENTRIES - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-  
- MAP_ENTRIES - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-  
- MAP_ENTRY_EVENT - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-  
- MAP_KEY_SET - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-  
- MAP_LOAD_ALL_KEYS_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
- 
- MAP_LOADER_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
- 
- MAP_NAME_PRECEDER - Static variable in class com.hazelcast.internal.ascii.memcache.MemcacheCommandProcessor
-  
- MAP_PARTITION_LOST_EVENT - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
-  
- MAP_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- MAP_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- MAP_REDUCE_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- MAP_REDUCE_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- MAP_REDUCE_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- MAP_REDUCE_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- MAP_REPLICATION_REMOVE - Static variable in class com.hazelcast.wan.impl.WanDataSerializerHook
- 
- MAP_REPLICATION_UPDATE - Static variable in class com.hazelcast.wan.impl.WanDataSerializerHook
- 
- MapAddEntryListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapAddEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerMessageTask
-  
- MapAddEntryListenerRequest - Class in com.hazelcast.map.impl.client
-  
- MapAddEntryListenerRequest() - Constructor for class com.hazelcast.map.impl.client.MapAddEntryListenerRequest
-  
- MapAddEntryListenerRequest(String, boolean, int) - Constructor for class com.hazelcast.map.impl.client.MapAddEntryListenerRequest
-  
- MapAddEntryListenerRequest(String, Data, boolean, Predicate, int) - Constructor for class com.hazelcast.map.impl.client.MapAddEntryListenerRequest
-  
- MapAddEntryListenerSqlRequest - Class in com.hazelcast.map.impl.client
-  
- MapAddEntryListenerSqlRequest() - Constructor for class com.hazelcast.map.impl.client.MapAddEntryListenerSqlRequest
-  
- MapAddEntryListenerSqlRequest(String, boolean, int) - Constructor for class com.hazelcast.map.impl.client.MapAddEntryListenerSqlRequest
-  
- MapAddEntryListenerSqlRequest(String, Data, boolean, int) - Constructor for class com.hazelcast.map.impl.client.MapAddEntryListenerSqlRequest
-  
- MapAddEntryListenerSqlRequest(String, Data, boolean, String, int) - Constructor for class com.hazelcast.map.impl.client.MapAddEntryListenerSqlRequest
-  
- MapAddEntryListenerToKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapAddEntryListenerToKeyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyMessageTask
-  
- MapAddEntryListenerToKeyWithPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapAddEntryListenerToKeyWithPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerToKeyWithPredicateMessageTask
-  
- MapAddEntryListenerWithPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapAddEntryListenerWithPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAddEntryListenerWithPredicateMessageTask
-  
- MapAddIndexMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapAddIndexMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAddIndexMessageTask
-  
- MapAddIndexRequest - Class in com.hazelcast.map.impl.client
-  
- MapAddIndexRequest() - Constructor for class com.hazelcast.map.impl.client.MapAddIndexRequest
-  
- MapAddIndexRequest(String, String, boolean) - Constructor for class com.hazelcast.map.impl.client.MapAddIndexRequest
-  
- MapAddInterceptorMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapAddInterceptorMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAddInterceptorMessageTask
-  
- MapAddInterceptorRequest - Class in com.hazelcast.map.impl.client
-  
- MapAddInterceptorRequest() - Constructor for class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-  
- MapAddInterceptorRequest(String, MapInterceptor) - Constructor for class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-  
- MapAddNearCacheEntryListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapAddNearCacheEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAddNearCacheEntryListenerMessageTask
-  
- MapAddNearCacheEntryListenerRequest - Class in com.hazelcast.map.impl.client
- 
- MapAddNearCacheEntryListenerRequest() - Constructor for class com.hazelcast.map.impl.client.MapAddNearCacheEntryListenerRequest
-  
- MapAddNearCacheEntryListenerRequest(String, boolean) - Constructor for class com.hazelcast.map.impl.client.MapAddNearCacheEntryListenerRequest
-  
- MapAddPartitionLostListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapAddPartitionLostListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
-  
- MapAddPartitionLostListenerRequest - Class in com.hazelcast.map.impl.client
-  
- MapAddPartitionLostListenerRequest() - Constructor for class com.hazelcast.map.impl.client.MapAddPartitionLostListenerRequest
-  
- MapAddPartitionLostListenerRequest(String) - Constructor for class com.hazelcast.map.impl.client.MapAddPartitionLostListenerRequest
-  
- MapAllPartitionsClientRequest - Class in com.hazelcast.map.impl.client
-  
- MapAllPartitionsClientRequest() - Constructor for class com.hazelcast.map.impl.client.MapAllPartitionsClientRequest
-  
- MapAllPartitionsClientRequest(String) - Constructor for class com.hazelcast.map.impl.client.MapAllPartitionsClientRequest
-  
- MapAttributeConfig - Class in com.hazelcast.config
- 
Contains the configuration of a custom attribute that will be extracted from a Map's entry using a given ValueExtractor. 
- MapAttributeConfig() - Constructor for class com.hazelcast.config.MapAttributeConfig
- 
Creates an empty MapAttributeConfig. 
- MapAttributeConfig(String, String) - Constructor for class com.hazelcast.config.MapAttributeConfig
- 
Creates a MapAttributeConfig with the given attribute and ordered setting. 
- MapAttributeConfig(MapAttributeConfig) - Constructor for class com.hazelcast.config.MapAttributeConfig
-  
- MapAttributeConfigReadOnly - Class in com.hazelcast.config
- 
Contains the configuration for a extractor of Map. 
- MapAttributeConfigReadOnly(MapAttributeConfig) - Constructor for class com.hazelcast.config.MapAttributeConfigReadOnly
-  
- mapCleared(MapEvent) - Method in class com.hazelcast.client.console.ClientConsoleApp
-  
- mapCleared(MapEvent) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
-  
- mapCleared(MapEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
-  
- mapCleared(MapEvent) - Method in class com.hazelcast.console.ConsoleApp
-  
- mapCleared(MapEvent) - Method in class com.hazelcast.core.EntryAdapter
-  
- mapCleared(MapEvent) - Method in class com.hazelcast.map.impl.MapListenerAdapter
-  
- mapCleared(MapEvent) - Method in interface com.hazelcast.map.listener.MapClearedListener
- 
- MapClearedListener - Interface in com.hazelcast.map.listener
- 
- MapClearMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapClearMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapClearMessageTask
-  
- MapClearNearCacheMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapClearNearCacheMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapClearNearCacheMessageTask
-  
- MapClearNearCacheRequest - Class in com.hazelcast.map.impl.client
-  
- MapClearNearCacheRequest() - Constructor for class com.hazelcast.map.impl.client.MapClearNearCacheRequest
-  
- MapClearNearCacheRequest(String, Address) - Constructor for class com.hazelcast.map.impl.client.MapClearNearCacheRequest
-  
- MapClearRequest - Class in com.hazelcast.map.impl.client
-  
- MapClearRequest() - Constructor for class com.hazelcast.map.impl.client.MapClearRequest
-  
- MapClearRequest(String) - Constructor for class com.hazelcast.map.impl.client.MapClearRequest
-  
- MapCombineTask<KeyIn,ValueIn,KeyOut,ValueOut,Chunk> - Class in com.hazelcast.mapreduce.impl.task
- 
This class acutally executed the mapping-combine phase. 
- MapCombineTask(JobTaskConfiguration, JobSupervisor, MappingPhase<KeyIn, ValueIn, KeyOut, ValueOut>) - Constructor for class com.hazelcast.mapreduce.impl.task.MapCombineTask
-  
- mapCombineTasks - Variable in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-  
- MapConfig - Class in com.hazelcast.config
- 
Contains the configuration for an  IMap. 
- MapConfig(String) - Constructor for class com.hazelcast.config.MapConfig
-  
- MapConfig() - Constructor for class com.hazelcast.config.MapConfig
-  
- MapConfig(MapConfig) - Constructor for class com.hazelcast.config.MapConfig
-  
- mapConfig - Variable in class com.hazelcast.map.impl.MapContainer
-  
- MapConfigDTO - Class in com.hazelcast.internal.management.dto
- 
- MapConfigDTO() - Constructor for class com.hazelcast.internal.management.dto.MapConfigDTO
-  
- MapConfigDTO(MapConfig) - Constructor for class com.hazelcast.internal.management.dto.MapConfigDTO
-  
- MapConfigReadOnly - Class in com.hazelcast.config
- 
Contains the configuration for an  IMap (read-only). 
- MapConfigRequest - Class in com.hazelcast.internal.management.request
- 
Request for updating map configuration from Management Center. 
- MapConfigRequest() - Constructor for class com.hazelcast.internal.management.request.MapConfigRequest
-  
- MapConfigRequest(String, MapConfigDTO, boolean) - Constructor for class com.hazelcast.internal.management.request.MapConfigRequest
-  
- MapConfigValidator - Class in com.hazelcast.map.impl
- 
Validates map configuration. 
- MapContainer - Class in com.hazelcast.map.impl
- 
Map container. 
- MapContainer(String, MapConfig, MapServiceContext) - Constructor for class com.hazelcast.map.impl.MapContainer
- 
- mapContainer - Variable in class com.hazelcast.map.impl.operation.MapOperation
-  
- MapContainsKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapContainsKeyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapContainsKeyMessageTask
-  
- MapContainsKeyRequest - Class in com.hazelcast.map.impl.client
-  
- MapContainsKeyRequest() - Constructor for class com.hazelcast.map.impl.client.MapContainsKeyRequest
-  
- MapContainsKeyRequest(String, Data) - Constructor for class com.hazelcast.map.impl.client.MapContainsKeyRequest
-  
- MapContainsKeyRequest(String, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapContainsKeyRequest
-  
- MapContainsValueMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapContainsValueMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapContainsValueMessageTask
-  
- MapContainsValueRequest - Class in com.hazelcast.map.impl.client
-  
- MapContainsValueRequest() - Constructor for class com.hazelcast.map.impl.client.MapContainsValueRequest
-  
- MapContainsValueRequest(String, Data) - Constructor for class com.hazelcast.map.impl.client.MapContainsValueRequest
-  
- MapDataSerializerHook - Class in com.hazelcast.map.impl
-  
- MapDataSerializerHook() - Constructor for class com.hazelcast.map.impl.MapDataSerializerHook
-  
- MapDataStore<K,V> - Interface in com.hazelcast.map.impl.mapstore
- 
Map data stores general contract. 
- MapDataStores - Class in com.hazelcast.map.impl.mapstore
- 
Factory class responsible for creating various data store implementations. 
- MapDelegatingSet<V> - Class in com.hazelcast.util.collection
- 
Read-only collection which delegates its operations to an underlying map and a couple of functions. 
- MapDelegatingSet(Map<?, ?>, Supplier<Iterator<V>>, Predicate) - Constructor for class com.hazelcast.util.collection.MapDelegatingSet
-  
- MapDeleteMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapDeleteMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapDeleteMessageTask
-  
- MapDeleteRequest - Class in com.hazelcast.map.impl.client
-  
- MapDeleteRequest() - Constructor for class com.hazelcast.map.impl.client.MapDeleteRequest
-  
- MapDeleteRequest(String, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapDeleteRequest
-  
- mapDrainIterator(int, Map) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- MapEntries - Class in com.hazelcast.map.impl
- 
MapEntries is a collection of  Map.Entry instances. 
- MapEntries() - Constructor for class com.hazelcast.map.impl.MapEntries
-  
- MapEntries(Collection<Map.Entry<Data, Data>>) - Constructor for class com.hazelcast.map.impl.MapEntries
-  
- MapEntriesWithPagingPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapEntriesWithPagingPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPagingPredicateMessageTask
-  
- MapEntriesWithPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapEntriesWithPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPredicateMessageTask
-  
- MapEntrySetMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapEntrySetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapEntrySetMessageTask
-  
- MapEntrySimple<K,V> - Class in com.hazelcast.map.impl
-  
- MapEntrySimple(K, V) - Constructor for class com.hazelcast.map.impl.MapEntrySimple
-  
- MapEvent - Class in com.hazelcast.core
- 
- MapEvent(Object, Member, int, int) - Constructor for class com.hazelcast.core.MapEvent
-  
- MapEventData - Class in com.hazelcast.map.impl.event
- 
Map wide event's data. 
- MapEventData() - Constructor for class com.hazelcast.map.impl.event.MapEventData
-  
- MapEventData(String, String, Address, int, int) - Constructor for class com.hazelcast.map.impl.event.MapEventData
-  
- MapEventPublisher - Interface in com.hazelcast.map.impl.event
- 
Helper methods for publishing events. 
- MapEventPublisherImpl - Class in com.hazelcast.map.impl.event
-  
- MapEventPublisherImpl(MapServiceContext) - Constructor for class com.hazelcast.map.impl.event.MapEventPublisherImpl
-  
- MapEventPublishingService - Class in com.hazelcast.map.impl.event
- 
Contains map service event publishing service functionality. 
- MapEventPublishingService(MapServiceContext) - Constructor for class com.hazelcast.map.impl.event.MapEventPublishingService
-  
- MapEvictAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapEvictAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapEvictAllMessageTask
-  
- MapEvictAllRequest - Class in com.hazelcast.map.impl.client
- 
Evict all entries request used by clients. 
- MapEvictAllRequest() - Constructor for class com.hazelcast.map.impl.client.MapEvictAllRequest
-  
- MapEvictAllRequest(String) - Constructor for class com.hazelcast.map.impl.client.MapEvictAllRequest
-  
- mapEvicted(MapEvent) - Method in class com.hazelcast.client.console.ClientConsoleApp
-  
- mapEvicted(MapEvent) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
-  
- mapEvicted(MapEvent) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
-  
- mapEvicted(MapEvent) - Method in class com.hazelcast.console.ConsoleApp
-  
- mapEvicted(MapEvent) - Method in class com.hazelcast.core.EntryAdapter
-  
- mapEvicted(MapEvent) - Method in class com.hazelcast.map.impl.MapListenerAdapter
-  
- mapEvicted(MapEvent) - Method in interface com.hazelcast.map.listener.MapEvictedListener
- 
- MapEvictedListener - Interface in com.hazelcast.map.listener
- 
- MapEvictMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapEvictMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapEvictMessageTask
-  
- MapEvictRequest - Class in com.hazelcast.map.impl.client
-  
- MapEvictRequest() - Constructor for class com.hazelcast.map.impl.client.MapEvictRequest
-  
- MapEvictRequest(String, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapEvictRequest
-  
- MapExecuteOnAllKeysMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapExecuteOnAllKeysMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnAllKeysMessageTask
-  
- MapExecuteOnAllKeysRequest - Class in com.hazelcast.map.impl.client
-  
- MapExecuteOnAllKeysRequest() - Constructor for class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-  
- MapExecuteOnAllKeysRequest(String, EntryProcessor) - Constructor for class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-  
- MapExecuteOnKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapExecuteOnKeyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeyMessageTask
-  
- MapExecuteOnKeyRequest - Class in com.hazelcast.map.impl.client
-  
- MapExecuteOnKeyRequest() - Constructor for class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-  
- MapExecuteOnKeyRequest(String, EntryProcessor, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-  
- MapExecuteOnKeysMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapExecuteOnKeysMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeysMessageTask
-  
- MapExecuteOnKeysRequest - Class in com.hazelcast.map.impl.client
-  
- MapExecuteOnKeysRequest() - Constructor for class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-  
- MapExecuteOnKeysRequest(String, EntryProcessor, Set<Data>) - Constructor for class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-  
- MapExecuteWithPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapExecuteWithPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapExecuteWithPredicateMessageTask
-  
- MapExecuteWithPredicateRequest - Class in com.hazelcast.map.impl.client
-  
- MapExecuteWithPredicateRequest() - Constructor for class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-  
- MapExecuteWithPredicateRequest(String, EntryProcessor, Predicate) - Constructor for class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-  
- MapFlushBackupOperation - Class in com.hazelcast.map.impl.operation
- 
- MapFlushBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.MapFlushBackupOperation
-  
- MapFlushBackupOperation(String) - Constructor for class com.hazelcast.map.impl.operation.MapFlushBackupOperation
-  
- MapFlushMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapFlushMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
-  
- MapFlushOperation - Class in com.hazelcast.map.impl.operation
- 
- MapFlushOperation() - Constructor for class com.hazelcast.map.impl.operation.MapFlushOperation
-  
- MapFlushOperation(String) - Constructor for class com.hazelcast.map.impl.operation.MapFlushOperation
-  
- MapFlushOperationFactory - Class in com.hazelcast.map.impl.operation
-  
- MapFlushOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.MapFlushOperationFactory
-  
- MapFlushOperationFactory(String) - Constructor for class com.hazelcast.map.impl.operation.MapFlushOperationFactory
-  
- MapFlushRequest - Class in com.hazelcast.map.impl.client
-  
- MapFlushRequest() - Constructor for class com.hazelcast.map.impl.client.MapFlushRequest
-  
- MapFlushRequest(String) - Constructor for class com.hazelcast.map.impl.client.MapFlushRequest
-  
- MapForceUnlockMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapForceUnlockMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapForceUnlockMessageTask
-  
- MapGetAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapGetAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapGetAllMessageTask
-  
- MapGetAllOperationFactory - Class in com.hazelcast.map.impl.operation
-  
- MapGetAllOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.MapGetAllOperationFactory
-  
- MapGetAllOperationFactory(String, List<Data>) - Constructor for class com.hazelcast.map.impl.operation.MapGetAllOperationFactory
-  
- MapGetAllRequest - Class in com.hazelcast.map.impl.client
-  
- MapGetAllRequest() - Constructor for class com.hazelcast.map.impl.client.MapGetAllRequest
-  
- MapGetAllRequest(String, List<Data>, int) - Constructor for class com.hazelcast.map.impl.client.MapGetAllRequest
-  
- MapGetEntryViewMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapGetEntryViewMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapGetEntryViewMessageTask
-  
- MapGetEntryViewRequest - Class in com.hazelcast.map.impl.client
-  
- MapGetEntryViewRequest() - Constructor for class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-  
- MapGetEntryViewRequest(String, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-  
- MapGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
-  
- MapGetRequest - Class in com.hazelcast.map.impl.client
-  
- MapGetRequest() - Constructor for class com.hazelcast.map.impl.client.MapGetRequest
-  
- MapGetRequest(String, Data) - Constructor for class com.hazelcast.map.impl.client.MapGetRequest
-  
- MapGetRequest(String, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapGetRequest
-  
- MapIndexConfig - Class in com.hazelcast.config
- 
Contains the configuration for an index in a map. 
- MapIndexConfig() - Constructor for class com.hazelcast.config.MapIndexConfig
- 
Creates a MapIndexConfig without an attribute and with ordered set to false. 
- MapIndexConfig(String, boolean) - Constructor for class com.hazelcast.config.MapIndexConfig
- 
Creates a MapIndexConfig with the given attribute and ordered setting. 
- MapIndexConfig(MapIndexConfig) - Constructor for class com.hazelcast.config.MapIndexConfig
-  
- MapIndexConfigReadOnly - Class in com.hazelcast.config
- 
Contains the configuration for a index of Map. 
- MapIndexConfigReadOnly(MapIndexConfig) - Constructor for class com.hazelcast.config.MapIndexConfigReadOnly
-  
- MapInterceptor - Interface in com.hazelcast.map
- 
MapInterceptor is used to intercept changes to the map, allowing access to the values before and
 after adding them to the map. 
- MapIsEmptyMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapIsEmptyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
-  
- MapIsEmptyOperation - Class in com.hazelcast.map.impl.operation
-  
- MapIsEmptyOperation(String) - Constructor for class com.hazelcast.map.impl.operation.MapIsEmptyOperation
-  
- MapIsEmptyOperation() - Constructor for class com.hazelcast.map.impl.operation.MapIsEmptyOperation
-  
- MapIsEmptyRequest - Class in com.hazelcast.map.impl.client
-  
- MapIsEmptyRequest() - Constructor for class com.hazelcast.map.impl.client.MapIsEmptyRequest
-  
- MapIsEmptyRequest(String) - Constructor for class com.hazelcast.map.impl.client.MapIsEmptyRequest
-  
- MapIsLockedMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapIsLockedMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapIsLockedMessageTask
-  
- MapIsLockedRequest - Class in com.hazelcast.map.impl.client
-  
- MapIsLockedRequest() - Constructor for class com.hazelcast.map.impl.client.MapIsLockedRequest
-  
- MapIsLockedRequest(String, Data) - Constructor for class com.hazelcast.map.impl.client.MapIsLockedRequest
-  
- mapIterateAndRemove(Map) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- MapKeyBasedClientRequest - Class in com.hazelcast.map.impl.client
-  
- MapKeyBasedClientRequest() - Constructor for class com.hazelcast.map.impl.client.MapKeyBasedClientRequest
-  
- MapKeyBasedClientRequest(String) - Constructor for class com.hazelcast.map.impl.client.MapKeyBasedClientRequest
-  
- MapKeyLoader - Class in com.hazelcast.map.impl
- 
Loads keys from a  MapLoader and sends them to all partitions for loading 
- MapKeyLoader(String, OperationService, InternalPartitionService, ExecutionService, IFunction<Object, Data>) - Constructor for class com.hazelcast.map.impl.MapKeyLoader
-  
- MapKeyLoaderUtil - Class in com.hazelcast.map.impl
-  
- MapKeySet - Class in com.hazelcast.map.impl
-  
- MapKeySet(Set<Data>) - Constructor for class com.hazelcast.map.impl.MapKeySet
-  
- MapKeySet() - Constructor for class com.hazelcast.map.impl.MapKeySet
-  
- MapKeySetMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapKeySetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
-  
- MapKeySetWithPagingPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapKeySetWithPagingPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPagingPredicateMessageTask
-  
- MapKeySetWithPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapKeySetWithPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
-  
- MapKeyValueSource<K,V> - Class in com.hazelcast.mapreduce.impl
- 
- MapKeyValueSource(String) - Constructor for class com.hazelcast.mapreduce.impl.MapKeyValueSource
-  
- MapListener - Interface in com.hazelcast.map.listener
- 
A marker interface which is used to get notified upon a map or an entry event. 
- MapListenerAdapter<K,V> - Class in com.hazelcast.map.impl
- 
- MapListenerAdapter() - Constructor for class com.hazelcast.map.impl.MapListenerAdapter
-  
- MapListenerAdaptors - Class in com.hazelcast.map.impl
- 
A static factory class which creates various
  ListenerAdapter implementations. 
- MapListenerFlagOperator - Class in com.hazelcast.map.impl
- 
Contains helper methods to set bit flags of implemented listener interfaces
 of a  MapListener. 
- MapLoadAllKeysRequest - Class in com.hazelcast.map.impl.client
- 
Triggers the load of all keys from defined map store. 
- MapLoadAllKeysRequest() - Constructor for class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-  
- MapLoadAllKeysRequest(String, boolean) - Constructor for class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-  
- MapLoadAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapLoadAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
-  
- MapLoadAllOperationFactory - Class in com.hazelcast.map.impl.operation
- 
Operation factory for load all operations. 
- MapLoadAllOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.MapLoadAllOperationFactory
-  
- MapLoadAllOperationFactory(String, List<Data>, boolean) - Constructor for class com.hazelcast.map.impl.operation.MapLoadAllOperationFactory
-  
- MapLoader<K,V> - Interface in com.hazelcast.core
- 
Hazelcast distributed map implementation is an in-memory data store but
 it can be backed by any type of data store such as RDBMS, OODBMS, or simply
 a file based data store. 
- MapLoaderLifecycleSupport - Interface in com.hazelcast.core
- 
Provides Lifecycle support for the implementing MapLoader class. 
- MapLoadGivenKeysMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapLoadGivenKeysMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
-  
- MapLoadGivenKeysRequest - Class in com.hazelcast.map.impl.client
- 
Loads all given keys from a map store. 
- MapLoadGivenKeysRequest() - Constructor for class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-  
- MapLoadGivenKeysRequest(String, List<Data>, boolean) - Constructor for class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-  
- MapLockMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapLockMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapLockMessageTask
-  
- MapLockRequest - Class in com.hazelcast.map.impl.client
-  
- MapLockRequest() - Constructor for class com.hazelcast.map.impl.client.MapLockRequest
-  
- MapLockRequest(String, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapLockRequest
-  
- MapLockRequest(String, Data, long, long, long) - Constructor for class com.hazelcast.map.impl.client.MapLockRequest
-  
- MapManagedService - Class in com.hazelcast.map.impl
- 
Defines managed service behavior of map service. 
- MapMBean - Class in com.hazelcast.jmx
- 
- MapMBean(IMap, ManagementService) - Constructor for class com.hazelcast.jmx.MapMBean
-  
- MapMergePolicy - Interface in com.hazelcast.map.merge
- 
A policy for merging maps after a splitbrain was detected and the different network partitions need
 to be merged. 
- MapOperation - Class in com.hazelcast.map.impl.operation
-  
- MapOperation() - Constructor for class com.hazelcast.map.impl.operation.MapOperation
-  
- MapOperation(String) - Constructor for class com.hazelcast.map.impl.operation.MapOperation
-  
- MapOperationProvider - Interface in com.hazelcast.map.impl.operation
- 
- MapOperationProviderDelegator - Class in com.hazelcast.map.impl.operation
- 
Base class which basically delegates all method calls to underlying  MapOperationProvider
 to prevent extending classes to override all methods. 
- MapOperationProviderDelegator() - Constructor for class com.hazelcast.map.impl.operation.MapOperationProviderDelegator
-  
- MapOperationProviders - Class in com.hazelcast.map.impl.operation
- 
- MapOperationProviders(MapServiceContext) - Constructor for class com.hazelcast.map.impl.operation.MapOperationProviders
-  
- MapPartitionClientRequest - Class in com.hazelcast.map.impl.client
-  
- MapPartitionClientRequest() - Constructor for class com.hazelcast.map.impl.client.MapPartitionClientRequest
-  
- MapPartitionClientRequest(String) - Constructor for class com.hazelcast.map.impl.client.MapPartitionClientRequest
-  
- MapPartitionDestroyTask - Class in com.hazelcast.map.impl.operation
-  
- MapPartitionDestroyTask(PartitionContainer, MapContainer, Semaphore) - Constructor for class com.hazelcast.map.impl.operation.MapPartitionDestroyTask
-  
- MapPartitionEventData - Class in com.hazelcast.map.impl.event
- 
Contains the data related to a map partition event 
- MapPartitionEventData() - Constructor for class com.hazelcast.map.impl.event.MapPartitionEventData
-  
- MapPartitionEventData(String, String, Address, int) - Constructor for class com.hazelcast.map.impl.event.MapPartitionEventData
-  
- MapPartitionLostEvent - Class in com.hazelcast.map
- 
Used for providing information about the lost partition for a map 
- MapPartitionLostEvent(Object, Member, int, int) - Constructor for class com.hazelcast.map.MapPartitionLostEvent
-  
- MapPartitionLostEventFilter - Class in com.hazelcast.map.impl
-  
- MapPartitionLostEventFilter() - Constructor for class com.hazelcast.map.impl.MapPartitionLostEventFilter
-  
- MapPartitionLostListener - Interface in com.hazelcast.map.listener
- 
Invoked when owner and all backups of a partition is lost for a specific map 
- MapPartitionLostListenerConfig - Class in com.hazelcast.config
- 
Configuration for MapPartitionLostListener 
- MapPartitionLostListenerConfig() - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
-  
- MapPartitionLostListenerConfig(String) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
-  
- MapPartitionLostListenerConfig(MapPartitionLostListener) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
-  
- MapPartitionLostListenerConfig(MapPartitionLostListenerConfig) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfig
-  
- MapPartitionLostListenerConfigReadOnly - Class in com.hazelcast.config
- 
Read-Only Configuration for MapPartitionLostListener 
- MapPartitionLostListenerConfigReadOnly(MapPartitionLostListenerConfig) - Constructor for class com.hazelcast.config.MapPartitionLostListenerConfigReadOnly
-  
- mapper - Variable in class com.hazelcast.mapreduce.impl.AbstractJob
-  
- mapper(Mapper<KeyIn, ValueIn, KeyOut, ValueOut>) - Method in class com.hazelcast.mapreduce.impl.AbstractJob
-  
- mapper - Variable in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-  
- mapper(Mapper<KeyIn, ValueIn, KeyOut, ValueOut>) - Method in interface com.hazelcast.mapreduce.Job
- 
Defines the mapper for this task. 
- Mapper<KeyIn,ValueIn,KeyOut,ValueOut> - Interface in com.hazelcast.mapreduce
- 
 The interface Mapper is used to build mappers for the  Job. 
- MapPermission - Class in com.hazelcast.security.permission
-  
- MapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.MapPermission
-  
- MappingJob<EntryKey,KeyIn,ValueIn> - Interface in com.hazelcast.mapreduce
- 
 This interface describes a mapping mapreduce Job. 
 For further information see  Job. 
- MappingPhase<KeyIn,ValueIn,KeyOut,ValueOut> - Class in com.hazelcast.mapreduce.impl.task
- 
This is the base of all mapping phase implementations. 
- MappingPhase(Collection<? extends KeyIn>, KeyPredicate<? super KeyIn>) - Constructor for class com.hazelcast.mapreduce.impl.task.MappingPhase
-  
- MapPortableHook - Class in com.hazelcast.map.impl
-  
- MapPortableHook() - Constructor for class com.hazelcast.map.impl.MapPortableHook
-  
- MapProxyImpl<K,V> - Class in com.hazelcast.map.impl.proxy
- 
Proxy implementation of  IMap interface. 
- MapProxyImpl(String, MapService, NodeEngine, MapConfig) - Constructor for class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- MapPutAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapPutAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
-  
- MapPutAllRequest - Class in com.hazelcast.map.impl.client
-  
- MapPutAllRequest() - Constructor for class com.hazelcast.map.impl.client.MapPutAllRequest
-  
- MapPutAllRequest(String, MapEntries, int) - Constructor for class com.hazelcast.map.impl.client.MapPutAllRequest
-  
- MapPutIfAbsentMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapPutIfAbsentMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapPutIfAbsentMessageTask
-  
- MapPutIfAbsentRequest - Class in com.hazelcast.map.impl.client
-  
- MapPutIfAbsentRequest() - Constructor for class com.hazelcast.map.impl.client.MapPutIfAbsentRequest
-  
- MapPutIfAbsentRequest(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapPutIfAbsentRequest
-  
- MapPutIfAbsentRequest(String, Data, Data, long, long) - Constructor for class com.hazelcast.map.impl.client.MapPutIfAbsentRequest
-  
- MapPutMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapPutMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapPutMessageTask
-  
- MapPutRequest - Class in com.hazelcast.map.impl.client
-  
- MapPutRequest() - Constructor for class com.hazelcast.map.impl.client.MapPutRequest
-  
- MapPutRequest(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapPutRequest
-  
- MapPutRequest(String, Data, Data, long, long) - Constructor for class com.hazelcast.map.impl.client.MapPutRequest
-  
- MapPutTransientMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapPutTransientMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapPutTransientMessageTask
-  
- MapPutTransientRequest - Class in com.hazelcast.map.impl.client
-  
- MapPutTransientRequest() - Constructor for class com.hazelcast.map.impl.client.MapPutTransientRequest
-  
- MapPutTransientRequest(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapPutTransientRequest
-  
- MapPutTransientRequest(String, Data, Data, long, long) - Constructor for class com.hazelcast.map.impl.client.MapPutTransientRequest
-  
- MapQueryEngine - Interface in com.hazelcast.map.impl.query
- 
Responsible for executing queries on the IMap. 
- MapQueryEngineImpl - Class in com.hazelcast.map.impl.query
- 
- MapQueryEngineImpl(MapServiceContext, QueryOptimizer) - Constructor for class com.hazelcast.map.impl.query.MapQueryEngineImpl
-  
- MapQueryEngineImpl.QueryPartitionCallable - Class in com.hazelcast.map.impl.query
-  
- MapQueryEngineImpl.QueryPartitionCallable(String, Predicate, int) - Constructor for class com.hazelcast.map.impl.query.MapQueryEngineImpl.QueryPartitionCallable
-  
- MapQueryRequest - Class in com.hazelcast.map.impl.client
- 
The MapQueryRequest can deal with a null predicate for the sake of security. 
- MapQueryRequest() - Constructor for class com.hazelcast.map.impl.client.MapQueryRequest
-  
- MapQueryRequest(String, Predicate, IterationType) - Constructor for class com.hazelcast.map.impl.client.MapQueryRequest
-  
- MapQuorumAwareService - Class in com.hazelcast.map.impl
- 
Quorum service will ask map service about whether map has defined quorum or not. 
- MapQuorumAwareService(MapServiceContext) - Constructor for class com.hazelcast.map.impl.MapQuorumAwareService
-  
- MapRecordKey - Class in com.hazelcast.map.impl
-  
- MapRecordKey(String, Data) - Constructor for class com.hazelcast.map.impl.MapRecordKey
-  
- MapReduceCancelMessageTask - Class in com.hazelcast.client.impl.protocol.task.mapreduce
-  
- MapReduceCancelMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceCancelMessageTask
-  
- MapReduceDataSerializerHook - Class in com.hazelcast.mapreduce.impl
- 
This class contains all the ID hooks for IdentifiedDataSerializable classes used inside the MR framework. 
- MapReduceDataSerializerHook() - Constructor for class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-  
- MapReduceForCustomMessageTask - Class in com.hazelcast.client.impl.protocol.task.mapreduce
-  
- MapReduceForCustomMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForCustomMessageTask
-  
- MapReduceForListMessageTask - Class in com.hazelcast.client.impl.protocol.task.mapreduce
-  
- MapReduceForListMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForListMessageTask
-  
- MapReduceForMapMessageTask - Class in com.hazelcast.client.impl.protocol.task.mapreduce
-  
- MapReduceForMapMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMapMessageTask
-  
- MapReduceForMultiMapMessageTask - Class in com.hazelcast.client.impl.protocol.task.mapreduce
-  
- MapReduceForMultiMapMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForMultiMapMessageTask
-  
- MapReduceForSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.mapreduce
-  
- MapReduceForSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceForSetMessageTask
-  
- MapReduceJobProcessInformationMessageTask - Class in com.hazelcast.client.impl.protocol.task.mapreduce
-  
- MapReduceJobProcessInformationMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceJobProcessInformationMessageTask
-  
- MapReduceNotification - Class in com.hazelcast.mapreduce.impl.notification
- 
Base class for all map reduce framework notifications 
- MapReduceNotification() - Constructor for class com.hazelcast.mapreduce.impl.notification.MapReduceNotification
-  
- MapReduceNotification(String, String) - Constructor for class com.hazelcast.mapreduce.impl.notification.MapReduceNotification
-  
- MapReducePermission - Class in com.hazelcast.security.permission
- 
To be able to map-reduce from a client in a secure environment 
- MapReducePermission(String, String...) - Constructor for class com.hazelcast.security.permission.MapReducePermission
-  
- MapReducePortableHook - Class in com.hazelcast.mapreduce.impl
- 
This class registers all Portable serializers that are needed for communication between nodes and clients 
- MapReducePortableHook() - Constructor for class com.hazelcast.mapreduce.impl.MapReducePortableHook
-  
- mapReduceService - Variable in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-  
- MapReduceService - Class in com.hazelcast.mapreduce.impl
- 
The MapReduceService class is the base point for the map reduce implementation. 
- MapReduceService(NodeEngine) - Constructor for class com.hazelcast.mapreduce.impl.MapReduceService
-  
- MapReduceUtil - Class in com.hazelcast.mapreduce.impl
- 
This utility class contains a few basic operations that are needed in multiple places 
- MapRemoveEntryListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapRemoveEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapRemoveEntryListenerMessageTask
-  
- MapRemoveEntryListenerRequest - Class in com.hazelcast.map.impl.client
-  
- MapRemoveEntryListenerRequest() - Constructor for class com.hazelcast.map.impl.client.MapRemoveEntryListenerRequest
-  
- MapRemoveEntryListenerRequest(String) - Constructor for class com.hazelcast.map.impl.client.MapRemoveEntryListenerRequest
-  
- MapRemoveIfSameMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapRemoveIfSameMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapRemoveIfSameMessageTask
-  
- MapRemoveIfSameRequest - Class in com.hazelcast.map.impl.client
-  
- MapRemoveIfSameRequest() - Constructor for class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-  
- MapRemoveIfSameRequest(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-  
- MapRemoveInterceptorMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapRemoveInterceptorMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapRemoveInterceptorMessageTask
-  
- MapRemoveInterceptorRequest - Class in com.hazelcast.map.impl.client
-  
- MapRemoveInterceptorRequest() - Constructor for class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-  
- MapRemoveInterceptorRequest(String, String) - Constructor for class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-  
- MapRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
-  
- MapRemovePartitionLostListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapRemovePartitionLostListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapRemovePartitionLostListenerMessageTask
-  
- MapRemovePartitionLostListenerRequest - Class in com.hazelcast.map.impl.client
-  
- MapRemovePartitionLostListenerRequest() - Constructor for class com.hazelcast.map.impl.client.MapRemovePartitionLostListenerRequest
-  
- MapRemovePartitionLostListenerRequest(String) - Constructor for class com.hazelcast.map.impl.client.MapRemovePartitionLostListenerRequest
-  
- MapRemoveRequest - Class in com.hazelcast.map.impl.client
-  
- MapRemoveRequest() - Constructor for class com.hazelcast.map.impl.client.MapRemoveRequest
-  
- MapRemoveRequest(String, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapRemoveRequest
-  
- MapReplaceIfSameMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapReplaceIfSameMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapReplaceIfSameMessageTask
-  
- MapReplaceIfSameRequest - Class in com.hazelcast.map.impl.client
-  
- MapReplaceIfSameRequest() - Constructor for class com.hazelcast.map.impl.client.MapReplaceIfSameRequest
-  
- MapReplaceIfSameRequest(String, Data, Data, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapReplaceIfSameRequest
-  
- MapReplaceMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapReplaceMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapReplaceMessageTask
-  
- MapReplaceRequest - Class in com.hazelcast.map.impl.client
-  
- MapReplaceRequest() - Constructor for class com.hazelcast.map.impl.client.MapReplaceRequest
-  
- MapReplaceRequest(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapReplaceRequest
-  
- MapReplicationOperation - Class in com.hazelcast.map.impl.operation
-  
- MapReplicationOperation() - Constructor for class com.hazelcast.map.impl.operation.MapReplicationOperation
-  
- MapReplicationOperation(MapService, PartitionContainer, int, int) - Constructor for class com.hazelcast.map.impl.operation.MapReplicationOperation
-  
- MapReplicationRemove - Class in com.hazelcast.map.impl.wan
-  
- MapReplicationRemove(String, Data, long) - Constructor for class com.hazelcast.map.impl.wan.MapReplicationRemove
-  
- MapReplicationRemove() - Constructor for class com.hazelcast.map.impl.wan.MapReplicationRemove
-  
- MapReplicationUpdate - Class in com.hazelcast.map.impl.wan
-  
- MapReplicationUpdate() - Constructor for class com.hazelcast.map.impl.wan.MapReplicationUpdate
-  
- MapReplicationUpdate(String, MapMergePolicy, EntryView) - Constructor for class com.hazelcast.map.impl.wan.MapReplicationUpdate
-  
- mapResultToMember(JobSupervisor, Map<K, V>) - Static method in class com.hazelcast.mapreduce.impl.task.MapCombineTask
-  
- MapService - Class in com.hazelcast.map.impl
- 
Defines map service behavior. 
- MapService() - Constructor for class com.hazelcast.map.impl.MapService
-  
- mapService - Variable in class com.hazelcast.map.impl.operation.MapOperation
-  
- MapServiceConstructor - Class in com.hazelcast.map.impl
- 
Helper which is used to create a  MapService object. 
- mapServiceContext - Variable in class com.hazelcast.map.impl.event.MapEventPublisherImpl
-  
- mapServiceContext - Variable in class com.hazelcast.map.impl.eviction.EvictionCheckerImpl
-  
- mapServiceContext - Variable in class com.hazelcast.map.impl.eviction.EvictorImpl
-  
- mapServiceContext - Variable in class com.hazelcast.map.impl.LocalMapStatsProvider
-  
- mapServiceContext - Variable in class com.hazelcast.map.impl.MapContainer
-  
- mapServiceContext - Variable in class com.hazelcast.map.impl.MapService
-  
- MapServiceContext - Interface in com.hazelcast.map.impl
- 
Context which is needed by a map service. 
- mapServiceContext - Variable in class com.hazelcast.map.impl.nearcache.AbstractNearCacheInvalidator
-  
- mapServiceContext - Variable in class com.hazelcast.map.impl.nearcache.NearCacheProvider
-  
- mapServiceContext - Variable in class com.hazelcast.map.impl.operation.MapOperation
-  
- mapServiceContext - Variable in class com.hazelcast.map.impl.operation.MapOperationProviders
-  
- mapServiceContext - Variable in class com.hazelcast.map.impl.query.MapQueryEngineImpl
-  
- mapServiceContext - Variable in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-  
- MapServiceContextEventListenerSupport - Interface in com.hazelcast.map.impl
- 
- MapServiceContextInterceptorSupport - Interface in com.hazelcast.map.impl
- 
- MapServiceFactory - Interface in com.hazelcast.map.impl
- 
- MapSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapSetMessageTask
-  
- MapSetRequest - Class in com.hazelcast.map.impl.client
-  
- MapSetRequest() - Constructor for class com.hazelcast.map.impl.client.MapSetRequest
-  
- MapSetRequest(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapSetRequest
-  
- MapSetRequest(String, Data, Data, long, long) - Constructor for class com.hazelcast.map.impl.client.MapSetRequest
-  
- mapSize(int) - Static method in class com.hazelcast.mapreduce.impl.MapReduceUtil
-  
- MapSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapSizeMessageTask
-  
- MapSizeOperation - Class in com.hazelcast.map.impl.operation
-  
- MapSizeOperation() - Constructor for class com.hazelcast.map.impl.operation.MapSizeOperation
-  
- MapSizeOperation(String) - Constructor for class com.hazelcast.map.impl.operation.MapSizeOperation
-  
- MapSizeRequest - Class in com.hazelcast.map.impl.client
-  
- MapSizeRequest() - Constructor for class com.hazelcast.map.impl.client.MapSizeRequest
-  
- MapSizeRequest(String) - Constructor for class com.hazelcast.map.impl.client.MapSizeRequest
-  
- MapSQLQueryRequest - Class in com.hazelcast.map.impl.client
-  
- MapSQLQueryRequest() - Constructor for class com.hazelcast.map.impl.client.MapSQLQueryRequest
-  
- MapSQLQueryRequest(String, String, IterationType) - Constructor for class com.hazelcast.map.impl.client.MapSQLQueryRequest
-  
- MapStore<K,V> - Interface in com.hazelcast.core
- 
Hazelcast distributed map implementation is an in-memory data store, but
 it can be backed by any type of data store such as RDBMS, OODBMS, NOSQL, or simply
 a file-based data store. 
- MapStoreAdapter<K,V> - Class in com.hazelcast.core
- 
Adapter for MapStore. 
- MapStoreAdapter() - Constructor for class com.hazelcast.core.MapStoreAdapter
-  
- MapStoreConfig - Class in com.hazelcast.config
- 
Contains the configuration for a Map Store. 
- MapStoreConfig() - Constructor for class com.hazelcast.config.MapStoreConfig
-  
- MapStoreConfig(MapStoreConfig) - Constructor for class com.hazelcast.config.MapStoreConfig
-  
- MapStoreConfig.InitialLoadMode - Enum in com.hazelcast.config
- 
Initial load module 
- MapStoreConfigReadOnly - Class in com.hazelcast.config
- 
Contains the configuration for a Map Store (read-only). 
- MapStoreConfigReadOnly(MapStoreConfig) - Constructor for class com.hazelcast.config.MapStoreConfigReadOnly
-  
- mapStoreContext - Variable in class com.hazelcast.map.impl.MapContainer
-  
- MapStoreContext - Interface in com.hazelcast.map.impl.mapstore
- 
A context which provides/initializes map store specific functionality. 
- MapStoreContextFactory - Class in com.hazelcast.map.impl.mapstore
- 
- MapStoreFactory<K,V> - Interface in com.hazelcast.core
- 
Factory for MapLoader or MapStore instances, specifiable in MapStoreConfig. 
- MapStoreManager - Interface in com.hazelcast.map.impl.mapstore
- 
Central interface to manage map store. 
- MapStoreManagers - Class in com.hazelcast.map.impl.mapstore
- 
Static factory class for various map store managers. 
- MapStoreWrapper - Class in com.hazelcast.map.impl
-  
- MapStoreWrapper(String, Object) - Constructor for class com.hazelcast.map.impl.MapStoreWrapper
-  
- MapSubmitToKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapSubmitToKeyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapSubmitToKeyMessageTask
-  
- MapTransactionLogRecord - Class in com.hazelcast.map.impl.tx
- 
Represents an operation on the map in the transaction log. 
- MapTransactionLogRecord() - Constructor for class com.hazelcast.map.impl.tx.MapTransactionLogRecord
-  
- MapTransactionLogRecord(String, Data, int, Operation, long, String) - Constructor for class com.hazelcast.map.impl.tx.MapTransactionLogRecord
-  
- MapTryLockMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapTryLockMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapTryLockMessageTask
-  
- MapTryPutMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapTryPutMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapTryPutMessageTask
-  
- MapTryPutRequest - Class in com.hazelcast.map.impl.client
-  
- MapTryPutRequest() - Constructor for class com.hazelcast.map.impl.client.MapTryPutRequest
-  
- MapTryPutRequest(String, Data, Data, long, long) - Constructor for class com.hazelcast.map.impl.client.MapTryPutRequest
-  
- MapTryRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapTryRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapTryRemoveMessageTask
-  
- MapTryRemoveRequest - Class in com.hazelcast.map.impl.client
-  
- MapTryRemoveRequest() - Constructor for class com.hazelcast.map.impl.client.MapTryRemoveRequest
-  
- MapTryRemoveRequest(String, Data, long, long) - Constructor for class com.hazelcast.map.impl.client.MapTryRemoveRequest
-  
- MapTxnOperation - Interface in com.hazelcast.map.impl.tx
- 
Transactional operation interface for  IMap
- MapUnlockMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapUnlockMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapUnlockMessageTask
-  
- MapUnlockRequest - Class in com.hazelcast.map.impl.client
-  
- MapUnlockRequest() - Constructor for class com.hazelcast.map.impl.client.MapUnlockRequest
-  
- MapUnlockRequest(String, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapUnlockRequest
-  
- MapUnlockRequest(String, Data, long, boolean) - Constructor for class com.hazelcast.map.impl.client.MapUnlockRequest
-  
- MapUtil - Class in com.hazelcast.util
- 
Utility class for Maps 
- MapValueCollection - Class in com.hazelcast.map.impl
-  
- MapValueCollection(Collection<Data>) - Constructor for class com.hazelcast.map.impl.MapValueCollection
-  
- MapValueCollection() - Constructor for class com.hazelcast.map.impl.MapValueCollection
-  
- MapValuesMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapValuesMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapValuesMessageTask
-  
- MapValuesWithPagingPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapValuesWithPagingPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPagingPredicateMessageTask
-  
- MapValuesWithPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.map
-  
- MapValuesWithPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPredicateMessageTask
-  
- mark(int) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- markerIdCounter - Variable in class com.hazelcast.hibernate.local.LocalRegionCache
-  
- MarkerWrapper - Class in com.hazelcast.hibernate.serialization
- 
A wrapper class for ExpiryMarker for returning copy of marker object with
 org.hibernate.cache.access.SoftLockmarker interface.
 
- MarkerWrapper(ExpiryMarker) - Constructor for class com.hazelcast.hibernate.serialization.MarkerWrapper
-  
- markForExpiration(long, String) - Method in class com.hazelcast.hibernate.serialization.Expirable
- 
Mark the entry for expiration with the given timeout and marker id. 
- markForExpiration(long, String) - Method in class com.hazelcast.hibernate.serialization.ExpiryMarker
-  
- markForExpiration(long, String) - Method in class com.hazelcast.hibernate.serialization.Value
-  
- markSupported() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- marshall(Object) - Method in class com.hazelcast.replicatedmap.impl.record.DataReplicatedRecordStore
-  
- marshall(Object) - Method in class com.hazelcast.replicatedmap.impl.record.ObjectReplicatedRecordStorage
-  
- marshall(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- mask - Variable in class com.hazelcast.security.permission.InstancePermission
-  
- masterAddress - Variable in class com.hazelcast.cluster.impl.operations.SetMasterOperation
-  
- MasterClaimOperation - Class in com.hazelcast.cluster.impl.operations
-  
- MasterClaimOperation() - Constructor for class com.hazelcast.cluster.impl.operations.MasterClaimOperation
-  
- MasterConfirmationOperation - Class in com.hazelcast.cluster.impl.operations
-  
- MasterConfirmationOperation() - Constructor for class com.hazelcast.cluster.impl.operations.MasterConfirmationOperation
-  
- MasterConfirmationOperation(long) - Constructor for class com.hazelcast.cluster.impl.operations.MasterConfirmationOperation
-  
- MasterDiscoveryOperation - Class in com.hazelcast.cluster.impl.operations
-  
- MasterDiscoveryOperation() - Constructor for class com.hazelcast.cluster.impl.operations.MasterDiscoveryOperation
-  
- MasterDiscoveryOperation(JoinMessage) - Constructor for class com.hazelcast.cluster.impl.operations.MasterDiscoveryOperation
-  
- masterTime - Variable in class com.hazelcast.cluster.impl.operations.MemberInfoUpdateOperation
-  
- match(String[], String[], int) - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
-  
- match(AddressUtil.AddressMatcher) - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
-  
- match(String) - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
-  
- matchAnyDomain(String, Collection<String>) - Static method in class com.hazelcast.util.AddressUtil
-  
- matchAnyInterface(String, Collection<String>) - Static method in class com.hazelcast.util.AddressUtil
-  
- matchDomain(String, String) - Static method in class com.hazelcast.util.AddressUtil
-  
- matches(Iterable<String>, String) - Method in interface com.hazelcast.config.ConfigPatternMatcher
- 
Returns the best match for an item name out of a list of configuration patterns. 
- matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.LegacyMatchingPointConfigPatternMatcher
- 
Deprecated. 
- matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.LegacyWildcardConfigPatternMatcher
- 
Deprecated. 
- matches(String, String) - Method in class com.hazelcast.config.matcher.LegacyWildcardConfigPatternMatcher
- 
Deprecated. 
- matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.MatchingPointConfigPatternMatcher
-  
- matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.RegexConfigPatternMatcher
-  
- matches(Iterable<String>, String) - Method in class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
-  
- matches(String, String) - Method in class com.hazelcast.config.matcher.WildcardConfigPatternMatcher
- 
- matches(ExpiryMarker) - Method in class com.hazelcast.hibernate.serialization.Expirable
-  
- matches(ExpiryMarker) - Method in class com.hazelcast.hibernate.serialization.ExpiryMarker
-  
- matches(ExpiryMarker) - Method in class com.hazelcast.hibernate.serialization.Value
-  
- matches(KeyIn) - Method in class com.hazelcast.mapreduce.impl.task.MappingPhase
-  
- MatchingPointConfigPatternMatcher - Class in com.hazelcast.config.matcher
- 
This ConfigPatternMatchersupports a simplified wildcard matching.
 
- MatchingPointConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.MatchingPointConfigPatternMatcher
-  
- matchInterface(String, String) - Static method in class com.hazelcast.util.AddressUtil
-  
- matchManagedConnections(Set, Subject, ConnectionRequestInfo) - Method in class com.hazelcast.jca.ManagedConnectionFactoryImpl
-  
- MAX_BACKOFF - Static variable in class com.hazelcast.client.proxy.ClientReliableTopicProxy
-  
- MAX_BACKOFF - Static variable in class com.hazelcast.topic.impl.reliable.ReliableTopicProxy
-  
- MAX_BACKUP_COUNT - Static variable in class com.hazelcast.config.CacheSimpleConfig
- 
The maximum number of backups. 
- MAX_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
- 
The number of maximum backup counter 
- MAX_BACKUP_COUNT - Static variable in interface com.hazelcast.partition.InternalPartition
-  
- MAX_BATCH_SIZE - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferProxy
- 
- MAX_CAPACITY - Static variable in class com.hazelcast.util.collection.IntHashSet
- 
Maximum supported capacity 
- MAX_CAPACITY - Static variable in class com.hazelcast.util.collection.LongHashSet
- 
Maximum supported capacity 
- MAX_EVICTION_PERCENTAGE - Static variable in class com.hazelcast.config.MapConfig
- 
The number of maximum eviction percentage 
- MAX_MESSAGE_SIZE_EXCEEDED - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- MAX_REPLICA_COUNT - Static variable in interface com.hazelcast.partition.InternalPartition
-  
- MAX_RESULT_LIMIT_FACTOR - Static variable in class com.hazelcast.map.impl.query.QueryResultSizeLimiter
- 
Adds a security margin to the configured result size limit to prevent false positives. 
- maxIdleMillis - Variable in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- maximumPoolSize - Variable in class com.hazelcast.internal.management.dto.ManagedExecutorDTO
-  
- MaxMessageSizeExceeded - Exception in com.hazelcast.client.impl.protocol.exception
- 
Thrown when client message size exceeds Integer.MAX_VALUE 
- MaxMessageSizeExceeded() - Constructor for exception com.hazelcast.client.impl.protocol.exception.MaxMessageSizeExceeded
-  
- maxPoolSize() - Method in class com.hazelcast.jmx.ManagedExecutorServiceMBean
-  
- maxSizeChecker - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- MaxSizeChecker - Interface in com.hazelcast.cache.impl.maxsize
- 
- maxSizeChecker - Variable in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- maxSizeCheckers - Variable in class com.hazelcast.cache.impl.maxsize.impl.CompositeMaxSizeChecker
-  
- MaxSizeConfig - Class in com.hazelcast.config
- 
Configuration for map's capacity. 
- MaxSizeConfig() - Constructor for class com.hazelcast.config.MaxSizeConfig
-  
- MaxSizeConfig(int, MaxSizeConfig.MaxSizePolicy) - Constructor for class com.hazelcast.config.MaxSizeConfig
-  
- MaxSizeConfig(MaxSizeConfig) - Constructor for class com.hazelcast.config.MaxSizeConfig
-  
- MaxSizeConfig.MaxSizePolicy - Enum in com.hazelcast.config
- 
Maximum Size Policy 
- MaxSizeConfigReadOnly - Class in com.hazelcast.config
- 
Contains the configuration for a size of Map. 
- MaxSizeConfigReadOnly(MaxSizeConfig) - Constructor for class com.hazelcast.config.MaxSizeConfigReadOnly
-  
- maxSizePolicy - Variable in class com.hazelcast.config.EvictionConfig
-  
- maybeDoInitialLoad() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- maybeDoInitialLoad() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
- 
Performs initial loading from a MapLoader if it has not been done before 
- maybeInvalidate(Object) - Method in class com.hazelcast.hibernate.local.LocalRegionCache
-  
- maybeInvalidate(Object) - Method in class com.hazelcast.hibernate.local.TimestampsRegionCache
-  
- maybeNotifyTopic(Object, Object, Object) - Method in class com.hazelcast.hibernate.local.LocalRegionCache
-  
- MD5Util - Class in com.hazelcast.util
- 
Utility class for hashing with MD5 
- megaBytes() - Method in class com.hazelcast.memory.MemorySize
- 
Returns value of memory size in mega-bytes. 
- MEM_COPY_THRESHOLD - Static variable in class com.hazelcast.nio.UnsafeHelper
-  
- MEMBER - Static variable in class com.hazelcast.cluster.impl.ClusterDataSerializerHook
-  
- Member - Interface in com.hazelcast.core
- 
Cluster member interface. 
- MEMBER_ADDED - Static variable in class com.hazelcast.cluster.client.ClientInitialMembershipEvent
-  
- MEMBER_ADDED - Static variable in class com.hazelcast.cluster.client.ClientMembershipEvent
-  
- MEMBER_ADDED - Static variable in class com.hazelcast.core.MembershipEvent
- 
This event type is fired when a new member joins the cluster. 
- MEMBER_ATTRIBUTE_CHANGED - Static variable in class com.hazelcast.cluster.client.ClientInitialMembershipEvent
-  
- MEMBER_ATTRIBUTE_CHANGED - Static variable in class com.hazelcast.cluster.client.ClientMembershipEvent
-  
- MEMBER_ATTRIBUTE_CHANGED - Static variable in class com.hazelcast.core.MembershipEvent
- 
This event type is fired if a member attribute has been changed or removed. 
- MEMBER_CALLABLE_TASK - Static variable in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
-  
- MEMBER_INFO_UPDATE - Static variable in class com.hazelcast.cluster.impl.ClusterDataSerializerHook
-  
- MEMBER_LEFT - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- MEMBER_REMOVED - Static variable in class com.hazelcast.cluster.client.ClientInitialMembershipEvent
-  
- MEMBER_REMOVED - Static variable in class com.hazelcast.cluster.client.ClientMembershipEvent
-  
- MEMBER_REMOVED - Static variable in class com.hazelcast.core.MembershipEvent
- 
This event type is fired if a member left the cluster or was decided to be
 unresponsive by other members for a extended time. 
- MEMBER_SELECTOR - Static variable in class com.hazelcast.mapreduce.impl.operation.KeyValueJobOperation
- 
Selects members that will run this operation 
- memberAdded(MembershipServiceEvent) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- memberAdded(MembershipEvent) - Method in class com.hazelcast.client.spi.impl.listener.ClientSmartListenerService
-  
- memberAdded(MembershipEvent) - Method in class com.hazelcast.client.util.AbstractLoadBalancer
-  
- memberAdded(MembershipServiceEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-  
- memberAdded(MembershipServiceEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-  
- memberAdded(MembershipEvent) - Method in class com.hazelcast.core.MembershipAdapter
-  
- memberAdded(MembershipEvent) - Method in interface com.hazelcast.core.MembershipListener
- 
Invoked when a new member is added to the cluster. 
- memberAdded(MembershipEvent) - Method in class com.hazelcast.internal.management.ManagementCenterService.MemberListenerImpl
-  
- memberAdded(MemberImpl) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- memberAdded(MemberImpl) - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- memberAdded(MembershipServiceEvent) - Method in class com.hazelcast.quorum.impl.QuorumServiceImpl
-  
- memberAdded(MembershipServiceEvent) - Method in interface com.hazelcast.spi.MembershipAwareService
- 
Invoked when a new member is added to the cluster. 
- memberAdded(MembershipServiceEvent) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-  
- memberAddresses - Variable in class com.hazelcast.cluster.impl.JoinMessage
-  
- MemberAssigningJobProcessInformationImpl - Class in com.hazelcast.mapreduce.impl.task
- 
This  JobProcessInformationImpl extending class is
 used in non partitionId based map reduce tasks where partitions are kind of simulated using
 a unique id per member. 
- MemberAssigningJobProcessInformationImpl(int, JobSupervisor) - Constructor for class com.hazelcast.mapreduce.impl.task.MemberAssigningJobProcessInformationImpl
-  
- MemberAttributeChange - Class in com.hazelcast.cluster.client
-  
- MemberAttributeChange() - Constructor for class com.hazelcast.cluster.client.MemberAttributeChange
-  
- MemberAttributeChange(String, MemberAttributeOperationType, String, Object) - Constructor for class com.hazelcast.cluster.client.MemberAttributeChange
-  
- memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- memberAttributeChanged(MemberAttributeEvent) - Method in class com.hazelcast.client.spi.impl.listener.ClientSmartListenerService
-  
- memberAttributeChanged(MemberAttributeEvent) - Method in class com.hazelcast.client.util.AbstractLoadBalancer
-  
- memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-  
- memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-  
- memberAttributeChanged(MemberAttributeEvent) - Method in class com.hazelcast.core.MembershipAdapter
-  
- memberAttributeChanged(MemberAttributeEvent) - Method in interface com.hazelcast.core.MembershipListener
- 
Invoked when an attribute of a member was changed. 
- memberAttributeChanged(MemberAttributeEvent) - Method in class com.hazelcast.internal.management.ManagementCenterService.MemberListenerImpl
-  
- memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.quorum.impl.QuorumServiceImpl
-  
- memberAttributeChanged(MemberAttributeServiceEvent) - Method in interface com.hazelcast.spi.MembershipAwareService
- 
Invoked when a member attribute is changed. 
- memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-  
- MemberAttributeChangedOperation - Class in com.hazelcast.cluster.impl.operations
-  
- MemberAttributeChangedOperation() - Constructor for class com.hazelcast.cluster.impl.operations.MemberAttributeChangedOperation
-  
- MemberAttributeChangedOperation(MemberAttributeOperationType, String, Object) - Constructor for class com.hazelcast.cluster.impl.operations.MemberAttributeChangedOperation
-  
- MemberAttributeConfig - Class in com.hazelcast.config
- 
Contains configuration for attribute of member. 
- MemberAttributeConfig() - Constructor for class com.hazelcast.config.MemberAttributeConfig
-  
- MemberAttributeConfig(MemberAttributeConfig) - Constructor for class com.hazelcast.config.MemberAttributeConfig
-  
- MemberAttributeConfigReadOnly - Class in com.hazelcast.config
- 
Contains configuration for attribute of member (Read-Only). 
- MemberAttributeEvent - Class in com.hazelcast.core
-  
- MemberAttributeEvent() - Constructor for class com.hazelcast.core.MemberAttributeEvent
-  
- MemberAttributeEvent(Cluster, Member, MemberAttributeOperationType, String, Object) - Constructor for class com.hazelcast.core.MemberAttributeEvent
-  
- MemberAttributeOperationType - Enum in com.hazelcast.cluster
- 
Used to identify the type of member attribute change, either PUT or REMOVED 
- MemberAttributeServiceEvent - Class in com.hazelcast.spi
- 
This service event is fired to inform services about a change in a member's attributes collection 
- MemberAttributeServiceEvent() - Constructor for class com.hazelcast.spi.MemberAttributeServiceEvent
-  
- MemberAttributeServiceEvent(Cluster, MemberImpl, MemberAttributeOperationType, String, Object) - Constructor for class com.hazelcast.spi.MemberAttributeServiceEvent
-  
- MemberAwareMapReduceNotification - Class in com.hazelcast.mapreduce.impl.notification
- 
Base class for all notifications based on a member 
- MemberAwareMapReduceNotification() - Constructor for class com.hazelcast.mapreduce.impl.notification.MemberAwareMapReduceNotification
-  
- MemberAwareMapReduceNotification(Address, String, String) - Constructor for class com.hazelcast.mapreduce.impl.notification.MemberAwareMapReduceNotification
-  
- MemberCallableTaskOperation - Class in com.hazelcast.executor.impl.operations
-  
- MemberCallableTaskOperation() - Constructor for class com.hazelcast.executor.impl.operations.MemberCallableTaskOperation
-  
- MemberCallableTaskOperation(String, String, Data) - Constructor for class com.hazelcast.executor.impl.operations.MemberCallableTaskOperation
-  
- MemberConfigRequest - Class in com.hazelcast.internal.management.request
- 
Request for fetching member XML configuration. 
- MemberConfigRequest() - Constructor for class com.hazelcast.internal.management.request.MemberConfigRequest
-  
- MemberGroup - Interface in com.hazelcast.partition.membergroup
-  
- MemberGroupConfig - Class in com.hazelcast.config
- 
Contains the configuration for a single member group. 
- MemberGroupConfig() - Constructor for class com.hazelcast.config.MemberGroupConfig
-  
- MemberGroupFactory - Interface in com.hazelcast.partition.membergroup
-  
- MemberGroupFactoryFactory - Class in com.hazelcast.partition.membergroup
-  
- MemberImpl - Class in com.hazelcast.client.impl
- 
Client side specific Member implementation. 
- MemberImpl() - Constructor for class com.hazelcast.client.impl.MemberImpl
-  
- MemberImpl(Address) - Constructor for class com.hazelcast.client.impl.MemberImpl
-  
- MemberImpl(Address, String) - Constructor for class com.hazelcast.client.impl.MemberImpl
-  
- MemberImpl(Address, String, Map<String, Object>, boolean) - Constructor for class com.hazelcast.client.impl.MemberImpl
-  
- MemberImpl(AbstractMember) - Constructor for class com.hazelcast.client.impl.MemberImpl
-  
- MemberImpl - Class in com.hazelcast.instance
-  
- MemberImpl() - Constructor for class com.hazelcast.instance.MemberImpl
-  
- MemberImpl(Address, boolean) - Constructor for class com.hazelcast.instance.MemberImpl
-  
- MemberImpl(Address, boolean, boolean) - Constructor for class com.hazelcast.instance.MemberImpl
-  
- MemberImpl(Address, boolean, String, HazelcastInstanceImpl) - Constructor for class com.hazelcast.instance.MemberImpl
-  
- MemberImpl(Address, boolean, String, HazelcastInstanceImpl, Map<String, Object>, boolean) - Constructor for class com.hazelcast.instance.MemberImpl
-  
- MemberImpl(MemberImpl) - Constructor for class com.hazelcast.instance.MemberImpl
-  
- MemberInfo - Class in com.hazelcast.cluster
-  
- MemberInfo() - Constructor for class com.hazelcast.cluster.MemberInfo
-  
- MemberInfo(Address) - Constructor for class com.hazelcast.cluster.MemberInfo
-  
- MemberInfo(Address, String, Map<String, Object>) - Constructor for class com.hazelcast.cluster.MemberInfo
-  
- MemberInfo(Address, String, Map<String, Object>, boolean) - Constructor for class com.hazelcast.cluster.MemberInfo
-  
- MemberInfo(MemberImpl) - Constructor for class com.hazelcast.cluster.MemberInfo
-  
- memberInfos - Variable in class com.hazelcast.cluster.impl.operations.MemberInfoUpdateOperation
-  
- MemberInfoUpdateOperation - Class in com.hazelcast.cluster.impl.operations
-  
- MemberInfoUpdateOperation() - Constructor for class com.hazelcast.cluster.impl.operations.MemberInfoUpdateOperation
-  
- MemberInfoUpdateOperation(Collection<MemberInfo>, long, boolean) - Constructor for class com.hazelcast.cluster.impl.operations.MemberInfoUpdateOperation
-  
- MemberLeftException - Exception in com.hazelcast.core
- 
- MemberLeftException() - Constructor for exception com.hazelcast.core.MemberLeftException
-  
- MemberLeftException(String) - Constructor for exception com.hazelcast.core.MemberLeftException
-  
- MemberLeftException(Member) - Constructor for exception com.hazelcast.core.MemberLeftException
-  
- memberNearCacheInvalidationEnabled - Variable in class com.hazelcast.map.impl.MapContainer
-  
- MemberPartitionState - Interface in com.hazelcast.monitor
- 
Partition related statistics 
- MemberPartitionStateImpl - Class in com.hazelcast.monitor.impl
- 
This class holds partition related statistics. 
- MemberPartitionStateImpl() - Constructor for class com.hazelcast.monitor.impl.MemberPartitionStateImpl
-  
- MemberReadHandler - Class in com.hazelcast.nio.tcp
- 
- MemberReadHandler(TcpIpConnection, PacketDispatcher) - Constructor for class com.hazelcast.nio.tcp.MemberReadHandler
-  
- memberRemoved(MembershipServiceEvent) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- memberRemoved(MembershipEvent) - Method in class com.hazelcast.client.spi.impl.listener.ClientSmartListenerService
-  
- memberRemoved(MembershipEvent) - Method in class com.hazelcast.client.util.AbstractLoadBalancer
-  
- memberRemoved(MembershipServiceEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-  
- memberRemoved(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-  
- memberRemoved(MembershipServiceEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-  
- memberRemoved(MembershipEvent) - Method in class com.hazelcast.core.MembershipAdapter
-  
- memberRemoved(MembershipEvent) - Method in interface com.hazelcast.core.MembershipListener
- 
Invoked when an existing member leaves the cluster. 
- memberRemoved(MembershipEvent) - Method in class com.hazelcast.internal.management.ManagementCenterService.MemberListenerImpl
-  
- memberRemoved(MemberImpl) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- memberRemoved(MemberImpl) - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- memberRemoved(MembershipServiceEvent) - Method in class com.hazelcast.quorum.impl.QuorumServiceImpl
-  
- memberRemoved(MembershipServiceEvent) - Method in interface com.hazelcast.spi.MembershipAwareService
- 
Invoked when an existing member leaves the cluster. 
- memberRemoved(MembershipServiceEvent) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-  
- MemberRemoveOperation - Class in com.hazelcast.cluster.impl.operations
-  
- MemberRemoveOperation() - Constructor for class com.hazelcast.cluster.impl.operations.MemberRemoveOperation
-  
- MemberRemoveOperation(Address) - Constructor for class com.hazelcast.cluster.impl.operations.MemberRemoveOperation
-  
- MemberSelectingCollection<M extends Member> - Class in com.hazelcast.cluster.impl
- 
An immutable collection that applies all the  MemberSelector instances to
 its internal  Member collection. 
- MemberSelectingCollection(Collection<M>, MemberSelector) - Constructor for class com.hazelcast.cluster.impl.MemberSelectingCollection
-  
- MemberSelector - Interface in com.hazelcast.core
- 
Implementations of this interface select members
 that are capable of executing a special kind of task. 
 The  MemberSelector.select(Member) method is called for every available
 member in the cluster and it is up to the implementation to decide
 if the member is going to be used or not. 
- MemberSelectors - Class in com.hazelcast.cluster.memberselector
- 
- MEMBERSHIP_EVENT - Static variable in class com.hazelcast.cluster.impl.ClusterDataSerializerHook
-  
- MEMBERSHIP_LISTENER - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-  
- MembershipAdapter - Class in com.hazelcast.core
- 
Adapter for MembershipListener. 
- MembershipAdapter() - Constructor for class com.hazelcast.core.MembershipAdapter
-  
- MembershipAwareService - Interface in com.hazelcast.spi
- 
An interface that can be implemented by a SPI service that needs to be notified members joining and leaving
 the cluster. 
- MembershipEvent - Class in com.hazelcast.core
- 
Membership event fired when a new member is added to the cluster and/or when a member leaves the cluster
 or when there is a member attribute change via  Member.setBooleanAttribute(String, boolean)
 and similar methods. 
- MembershipEvent(Cluster, Member, int, Set<Member>) - Constructor for class com.hazelcast.core.MembershipEvent
-  
- MembershipListener - Interface in com.hazelcast.core
- 
Cluster membership listener. 
- MembershipServiceEvent - Class in com.hazelcast.spi
- 
Membership event fired when a new member is added
 to the cluster and/or when a member leaves the cluster. 
- MembershipServiceEvent(MembershipEvent) - Constructor for class com.hazelcast.spi.MembershipServiceEvent
-  
- MemberSocketInterceptor - Interface in com.hazelcast.nio
- 
- membersString() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- MemberState - Interface in com.hazelcast.monitor
-  
- MemberStateImpl - Class in com.hazelcast.monitor.impl
-  
- MemberStateImpl() - Constructor for class com.hazelcast.monitor.impl.MemberStateImpl
-  
- MemberWriteHandler - Class in com.hazelcast.nio.tcp
- 
- MemberWriteHandler() - Constructor for class com.hazelcast.nio.tcp.MemberWriteHandler
-  
- MemcacheCommandProcessor<T> - Class in com.hazelcast.internal.ascii.memcache
-  
- MemcacheCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.memcache.MemcacheCommandProcessor
-  
- MemcacheEntry - Class in com.hazelcast.internal.ascii.memcache
-  
- MemcacheEntry(String, byte[], int) - Constructor for class com.hazelcast.internal.ascii.memcache.MemcacheEntry
-  
- MemcacheEntry() - Constructor for class com.hazelcast.internal.ascii.memcache.MemcacheEntry
-  
- memoryInfoAccessor - Variable in class com.hazelcast.map.impl.eviction.EvictionCheckerImpl
-  
- MemoryInfoAccessor - Interface in com.hazelcast.util
- 
Used for providing runtime memory information of Java virtual machine. 
- MemorySize - Class in com.hazelcast.memory
- 
MemorySize represents a memory size with given value and MemoryUnit. 
- MemorySize(long) - Constructor for class com.hazelcast.memory.MemorySize
-  
- MemorySize(long, MemoryUnit) - Constructor for class com.hazelcast.memory.MemorySize
-  
- MemoryStats - Interface in com.hazelcast.memory
- 
Memory statistics for the JVM which current HazelcastInstance belongs to. 
- MemoryStatsSupport - Class in com.hazelcast.memory
- 
This class provides heap usage statistics 
- MemoryUnit - Enum in com.hazelcast.memory
- 
MemoryUnit represents memory size at a given unit of
 granularity and provides utility methods to convert across units. 
- merge(String, CacheEntryView, CacheEntryView) - Method in interface com.hazelcast.cache.CacheMergePolicy
- 
 Selects one of the merging and existing cache entries to be merged. 
- MERGE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- merge(CacheEntryView<Data, Data>, CacheMergePolicy) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-  
- merge(CacheEntryView<Data, Data>, CacheMergePolicy) - Method in interface com.hazelcast.cache.impl.SplitBrainAwareCacheRecordStore
- 
- merge(String, CacheEntryView, CacheEntryView) - Method in class com.hazelcast.cache.merge.HigherHitsCacheMergePolicy
-  
- merge(String, CacheEntryView, CacheEntryView) - Method in class com.hazelcast.cache.merge.LatestAccessCacheMergePolicy
-  
- merge(String, CacheEntryView, CacheEntryView) - Method in class com.hazelcast.cache.merge.PassThroughCacheMergePolicy
-  
- merge(String, CacheEntryView, CacheEntryView) - Method in class com.hazelcast.cache.merge.PutIfAbsentCacheMergePolicy
-  
- merge(Address) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- merge(String, EntryView, EntryView) - Method in class com.hazelcast.hibernate.VersionAwareMapMergePolicy
-  
- merge(Data, EntryView, MapMergePolicy) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- merge(Data, EntryView, MapMergePolicy) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- merge(String, EntryView, EntryView) - Method in class com.hazelcast.map.merge.HigherHitsMapMergePolicy
-  
- merge(String, EntryView, EntryView) - Method in class com.hazelcast.map.merge.LatestUpdateMapMergePolicy
-  
- merge(String, EntryView, EntryView) - Method in interface com.hazelcast.map.merge.MapMergePolicy
- 
Returns the value of the entry after the merge
 of entries with the same key. 
- merge(String, EntryView, EntryView) - Method in class com.hazelcast.map.merge.PassThroughMergePolicy
-  
- merge(String, EntryView, EntryView) - Method in class com.hazelcast.map.merge.PutIfAbsentMapMergePolicy
-  
- merge(Object, ReplicatedMapEntryView, ReplicatedMapMergePolicy) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-  
- merge(Object, ReplicatedMapEntryView, ReplicatedMapMergePolicy) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- merge(String, ReplicatedMapEntryView, ReplicatedMapEntryView) - Method in class com.hazelcast.replicatedmap.merge.HigherHitsMapMergePolicy
-  
- merge(String, ReplicatedMapEntryView, ReplicatedMapEntryView) - Method in class com.hazelcast.replicatedmap.merge.LatestUpdateMapMergePolicy
-  
- merge(String, ReplicatedMapEntryView, ReplicatedMapEntryView) - Method in class com.hazelcast.replicatedmap.merge.PassThroughMergePolicy
-  
- merge(String, ReplicatedMapEntryView, ReplicatedMapEntryView) - Method in class com.hazelcast.replicatedmap.merge.PutIfAbsentMapMergePolicy
-  
- merge(String, ReplicatedMapEntryView, ReplicatedMapEntryView) - Method in interface com.hazelcast.replicatedmap.merge.ReplicatedMapMergePolicy
- 
Returns the value of the entry after the merge
 of entries with the same key. 
- MergeClustersOperation - Class in com.hazelcast.cluster.impl.operations
-  
- MergeClustersOperation() - Constructor for class com.hazelcast.cluster.impl.operations.MergeClustersOperation
-  
- MergeClustersOperation(Address) - Constructor for class com.hazelcast.cluster.impl.operations.MergeClustersOperation
-  
- MergeOperation - Class in com.hazelcast.map.impl.operation
-  
- MergeOperation(String, Data, EntryView<Data, Data>, MapMergePolicy) - Constructor for class com.hazelcast.map.impl.operation.MergeOperation
-  
- MergeOperation(String, Data, EntryView<Data, Data>, MapMergePolicy, boolean) - Constructor for class com.hazelcast.map.impl.operation.MergeOperation
-  
- MergeOperation() - Constructor for class com.hazelcast.map.impl.operation.MergeOperation
-  
- MergeOperation - Class in com.hazelcast.replicatedmap.impl.operation
- 
Merges two replicated map entries with the given merge policy after the split-brain syndrome is recovered. 
- MergeOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.MergeOperation
-  
- MergeOperation(String, Object, ReplicatedMapEntryView, ReplicatedMapMergePolicy) - Constructor for class com.hazelcast.replicatedmap.impl.operation.MergeOperation
-  
- MergePolicyProvider - Class in com.hazelcast.map.merge
- 
- MergePolicyProvider(NodeEngine) - Constructor for class com.hazelcast.map.merge.MergePolicyProvider
-  
- MergePolicyProvider - Class in com.hazelcast.replicatedmap.merge
- 
- MergePolicyProvider(NodeEngine) - Constructor for class com.hazelcast.replicatedmap.merge.MergePolicyProvider
-  
- mergingValue - Variable in class com.hazelcast.core.EntryEvent
-  
- Message<E> - Class in com.hazelcast.core
- 
- Message(String, E, long, Member) - Constructor for class com.hazelcast.core.Message
-  
- MessageFlyweight - Class in com.hazelcast.client.impl.protocol.util
- 
Parameter Flyweight 
- MessageFlyweight() - Constructor for class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- MessageListener<E> - Interface in com.hazelcast.core
- 
- messageListener - Variable in class com.hazelcast.hibernate.local.LocalRegionCache
-  
- messageObject - Variable in class com.hazelcast.core.Message
-  
- MessageTask - Interface in com.hazelcast.client.impl.protocol.task
- 
Interface for all client message tasks to implement 
- MessageTaskFactory - Interface in com.hazelcast.client.impl.protocol
- 
Message task factory interface 
- MessageTaskFactoryImpl - Class in com.hazelcast.client.impl.protocol
-  
- MessageTaskFactoryImpl(Node) - Constructor for class com.hazelcast.client.impl.protocol.MessageTaskFactoryImpl
-  
- Metric - Interface in com.hazelcast.internal.metrics
- 
A Metric is a 'quantitative measure' of something for example the number of operations pending, number of operations
 per second being executed etc. 
- MetricsRegistry - Interface in com.hazelcast.internal.metrics
- 
The MetricsRegistry is responsible for recording all kinds of Hazelcast/JVM specific information to
 help out with issues like performance or stability problems. 
- MetricsRegistryImpl - Class in com.hazelcast.internal.metrics.impl
- 
- MetricsRegistryImpl(ILogger, ProbeLevel) - Constructor for class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
- 
Creates a MetricsRegistryImpl instance. 
- MigratableHandler - Interface in com.hazelcast.nio.tcp.nonblocking
- 
- MIGRATION_EVENT_TOPIC - Static variable in interface com.hazelcast.partition.InternalPartitionService
- 
Static constant for dispatching and listening migration events 
- migrationAwareService - Variable in class com.hazelcast.map.impl.MapService
-  
- MigrationAwareService - Interface in com.hazelcast.spi
- 
An interface that can be implemented by SPI services to get notified of partition changes; for example, if a
  MapService starts moving its data around because partitions are moving
 to a different machine. 
- migrationCompleted(MigrationEvent) - Method in interface com.hazelcast.core.MigrationListener
- 
Invoked when a partition migration is completed. 
- MigrationCycleOperation - Interface in com.hazelcast.partition
-  
- migrationData - Variable in class com.hazelcast.collection.impl.collection.operations.CollectionReplicationOperation
-  
- MigrationEndpoint - Enum in com.hazelcast.partition
-  
- MigrationEvent - Class in com.hazelcast.core
- 
An event fired when a partition migration starts, completes or fails. 
- MigrationEvent() - Constructor for class com.hazelcast.core.MigrationEvent
-  
- MigrationEvent(int, Member, Member, MigrationEvent.MigrationStatus) - Constructor for class com.hazelcast.core.MigrationEvent
-  
- MigrationEvent.MigrationStatus - Enum in com.hazelcast.core
- 
Migration status: Started, completed or failed 
- migrationFailed(MigrationEvent) - Method in interface com.hazelcast.core.MigrationListener
- 
Invoked when a partition migration is failed. 
- migrationInfo - Variable in class com.hazelcast.partition.impl.BaseMigrationOperation
-  
- MigrationInfo - Class in com.hazelcast.partition
-  
- MigrationInfo() - Constructor for class com.hazelcast.partition.MigrationInfo
-  
- MigrationInfo(int, Address, Address) - Constructor for class com.hazelcast.partition.MigrationInfo
-  
- MigrationListener - Interface in com.hazelcast.core
- 
MigrationListener provides the ability to listen to partition migration events. 
- MigrationOperation - Class in com.hazelcast.partition.impl
-  
- MigrationOperation() - Constructor for class com.hazelcast.partition.impl.MigrationOperation
-  
- MigrationOperation(MigrationInfo, long[], Collection<Operation>) - Constructor for class com.hazelcast.partition.impl.MigrationOperation
-  
- MigrationRequestOperation - Class in com.hazelcast.partition.impl
-  
- MigrationRequestOperation() - Constructor for class com.hazelcast.partition.impl.MigrationRequestOperation
-  
- MigrationRequestOperation(MigrationInfo) - Constructor for class com.hazelcast.partition.impl.MigrationRequestOperation
-  
- migrationStarted(MigrationEvent) - Method in interface com.hazelcast.core.MigrationListener
- 
Invoked when a partition migration is started. 
- MIN_BACKUP_COUNT - Static variable in class com.hazelcast.config.CacheSimpleConfig
- 
The minimum number of backups. 
- MIN_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
- 
The number of minimum backup counter 
- MIN_EVICTION_PERCENTAGE - Static variable in class com.hazelcast.config.MapConfig
- 
The number of minimum eviction percentage 
- MIN_INITIAL_MEMORY_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
- 
Minimum initial memory size in megabytes 
- MINIMUM_MAX_RESULT_LIMIT - Static variable in class com.hazelcast.map.impl.query.QueryResultSizeLimiter
- 
Defines the minimum value for the result size limit to ensure a sufficient distribution of data in the partitions. 
- MISSES - Static variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- misses - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- modifyOutputStream(JarOutputStream) - Method in class com.hazelcast.buildutils.HazelcastManifestTransformer
-  
- ModifyRequest - Class in com.hazelcast.concurrent.atomicreference.client
-  
- ModifyRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.ModifyRequest
-  
- ModifyRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.ModifyRequest
-  
- modPowerOfTwo(int, int) - Static method in class com.hazelcast.util.QuickMath
- 
Computes the remainder of the division of abyb.
 
- modPowerOfTwo(long, int) - Static method in class com.hazelcast.util.QuickMath
- 
Computes the remainder of the division of abyb.
 
- MonitoredThread - Class in com.hazelcast.internal.management
- 
Holds monitoring information( CPU percentage etc.) for threads. 
- MonitoredThread(String, long, int) - Constructor for class com.hazelcast.internal.management.MonitoredThread
-  
- MorphingPortableReader - Class in com.hazelcast.internal.serialization.impl
- 
Enables reading from a portable byte stream if the portableVersion from the classDefinition is different than
 the portableVersion from the byte stream. 
- MorphingPortableReader(PortableSerializer, BufferObjectDataInput, ClassDefinition) - Constructor for class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- MulticastConfig - Class in com.hazelcast.config
- 
Contains the configuration for the multicast discovery mechanism. 
- MulticastConfig() - Constructor for class com.hazelcast.config.MulticastConfig
-  
- MulticastJoiner - Class in com.hazelcast.cluster.impl
-  
- MulticastJoiner(Node) - Constructor for class com.hazelcast.cluster.impl.MulticastJoiner
-  
- MulticastListener - Interface in com.hazelcast.cluster.impl
-  
- MulticastService - Class in com.hazelcast.cluster.impl
-  
- multicastService - Variable in class com.hazelcast.instance.Node
-  
- MultiExecutionCallback - Interface in com.hazelcast.core
- 
MultiExecutionCallback provides notification for when an execution is completed on each member
 that a task is submitted to. 
- MultiMap<K,V> - Interface in com.hazelcast.core
- 
A specialized map whose keys can be associated with multiple values. 
- MULTIMAP_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- MULTIMAP_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- MULTIMAP_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- MULTIMAP_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- MultiMapAddEntryListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_ADDENTRYLISTENER
 
- MultiMapAddEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerMessageTask
-  
- MultiMapAddEntryListenerToKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_ADDENTRYLISTENERTOKEY
 
- MultiMapAddEntryListenerToKeyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerToKeyMessageTask
-  
- MultiMapAllPartitionRequest - Class in com.hazelcast.multimap.impl.client
-  
- MultiMapAllPartitionRequest() - Constructor for class com.hazelcast.multimap.impl.client.MultiMapAllPartitionRequest
-  
- MultiMapAllPartitionRequest(String) - Constructor for class com.hazelcast.multimap.impl.client.MultiMapAllPartitionRequest
-  
- MultiMapBackupAwareOperation - Class in com.hazelcast.multimap.impl.operations
-  
- MultiMapBackupAwareOperation() - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapBackupAwareOperation
-  
- MultiMapBackupAwareOperation(String, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapBackupAwareOperation
-  
- MultiMapClearMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_CLEAR
 
- MultiMapClearMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapClearMessageTask
-  
- MultiMapConfig - Class in com.hazelcast.config
- 
Configuration for MultiMap. 
- MultiMapConfig() - Constructor for class com.hazelcast.config.MultiMapConfig
-  
- MultiMapConfig(String) - Constructor for class com.hazelcast.config.MultiMapConfig
-  
- MultiMapConfig(MultiMapConfig) - Constructor for class com.hazelcast.config.MultiMapConfig
-  
- MultiMapConfig.ValueCollectionType - Enum in com.hazelcast.config
- 
Type of value collection 
- MultiMapConfigReadOnly - Class in com.hazelcast.config
- 
Contains the configuration for an  MultiMap. 
- MultiMapConfigReadOnly(MultiMapConfig) - Constructor for class com.hazelcast.config.MultiMapConfigReadOnly
-  
- MultiMapContainer - Class in com.hazelcast.multimap.impl
- 
- MultiMapContainer(String, MultiMapService, int) - Constructor for class com.hazelcast.multimap.impl.MultiMapContainer
-  
- MultiMapContainsEntryMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_CONTAINSENTRY
 
- MultiMapContainsEntryMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsEntryMessageTask
-  
- MultiMapContainsKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_CONTAINSKEY
 
- MultiMapContainsKeyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsKeyMessageTask
-  
- MultiMapContainsValueMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_CONTAINSVALUE
 
- MultiMapContainsValueMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsValueMessageTask
-  
- MultiMapDataSerializerHook - Class in com.hazelcast.multimap.impl
-  
- MultiMapDataSerializerHook() - Constructor for class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- MultiMapEntrySetMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_ENTRYSET
 
- MultiMapEntrySetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
-  
- MultiMapEventFilter - Class in com.hazelcast.multimap.impl
-  
- MultiMapEventFilter() - Constructor for class com.hazelcast.multimap.impl.MultiMapEventFilter
-  
- MultiMapEventFilter(boolean, Data) - Constructor for class com.hazelcast.multimap.impl.MultiMapEventFilter
-  
- MultiMapEventsPublisher - Class in com.hazelcast.multimap.impl
- 
Publishes multimap entry and map events through eventService 
- MultiMapEventsPublisher(NodeEngine) - Constructor for class com.hazelcast.multimap.impl.MultiMapEventsPublisher
-  
- MultiMapForceUnlockMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_FORCEUNLOCK
 
- MultiMapForceUnlockMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapForceUnlockMessageTask
-  
- MultiMapGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_GET
 
- MultiMapGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapGetMessageTask
-  
- MultiMapIsLockedMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_ISLOCKED
 
- MultiMapIsLockedMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapIsLockedMessageTask
-  
- MultiMapIsLockedRequest - Class in com.hazelcast.multimap.impl.client
-  
- MultiMapIsLockedRequest() - Constructor for class com.hazelcast.multimap.impl.client.MultiMapIsLockedRequest
-  
- MultiMapIsLockedRequest(Data, String) - Constructor for class com.hazelcast.multimap.impl.client.MultiMapIsLockedRequest
-  
- MultiMapKeyBasedOperation - Class in com.hazelcast.multimap.impl.operations
-  
- MultiMapKeyBasedOperation() - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-  
- MultiMapKeyBasedOperation(String, Data) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-  
- MultiMapKeyBasedOperation(String, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-  
- MultiMapKeyBasedRequest - Class in com.hazelcast.multimap.impl.client
-  
- MultiMapKeyBasedRequest() - Constructor for class com.hazelcast.multimap.impl.client.MultiMapKeyBasedRequest
-  
- MultiMapKeyBasedRequest(String, Data) - Constructor for class com.hazelcast.multimap.impl.client.MultiMapKeyBasedRequest
-  
- MultiMapKeySetMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_KEYSET
 
- MultiMapKeySetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
-  
- MultiMapKeyValueSource<K,V> - Class in com.hazelcast.mapreduce.impl
- 
- MultiMapKeyValueSource(String) - Constructor for class com.hazelcast.mapreduce.impl.MultiMapKeyValueSource
-  
- MultiMapLockMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_LOCK
 
- MultiMapLockMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapLockMessageTask
-  
- MultiMapLockRequest - Class in com.hazelcast.multimap.impl.client
-  
- MultiMapLockRequest() - Constructor for class com.hazelcast.multimap.impl.client.MultiMapLockRequest
-  
- MultiMapLockRequest(Data, long, String) - Constructor for class com.hazelcast.multimap.impl.client.MultiMapLockRequest
-  
- MultiMapLockRequest(Data, long, long, long, String) - Constructor for class com.hazelcast.multimap.impl.client.MultiMapLockRequest
-  
- MultiMapMBean - Class in com.hazelcast.jmx
- 
- MultiMapMBean(MultiMap, ManagementService) - Constructor for class com.hazelcast.jmx.MultiMapMBean
-  
- MultiMapMigrationOperation - Class in com.hazelcast.multimap.impl.operations
-  
- MultiMapMigrationOperation() - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapMigrationOperation
-  
- MultiMapMigrationOperation(Map<String, Map>) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapMigrationOperation
-  
- MultiMapOperation - Class in com.hazelcast.multimap.impl.operations
-  
- MultiMapOperation() - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapOperation
-  
- MultiMapOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapOperation
-  
- MultiMapOperationFactory - Class in com.hazelcast.multimap.impl.operations
-  
- MultiMapOperationFactory() - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
-  
- MultiMapOperationFactory(String, MultiMapOperationFactory.OperationFactoryType) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
-  
- MultiMapOperationFactory(String, MultiMapOperationFactory.OperationFactoryType, Data, Data) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
-  
- MultiMapOperationFactory(String, MultiMapOperationFactory.OperationFactoryType, Data, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
-  
- MultiMapOperationFactory.OperationFactoryType - Enum in com.hazelcast.multimap.impl.operations
-  
- MultiMapPartitionContainer - Class in com.hazelcast.multimap.impl
-  
- MultiMapPartitionContainer(MultiMapService, int) - Constructor for class com.hazelcast.multimap.impl.MultiMapPartitionContainer
-  
- MultiMapPermission - Class in com.hazelcast.security.permission
-  
- MultiMapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.MultiMapPermission
-  
- MultiMapPortableHook - Class in com.hazelcast.multimap.impl
-  
- MultiMapPortableHook() - Constructor for class com.hazelcast.multimap.impl.MultiMapPortableHook
-  
- MultiMapProxySupport - Class in com.hazelcast.multimap.impl
-  
- MultiMapProxySupport(MultiMapService, NodeEngine, String) - Constructor for class com.hazelcast.multimap.impl.MultiMapProxySupport
-  
- MultiMapPutMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_PUT
 
- MultiMapPutMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapPutMessageTask
-  
- MultiMapRecord - Class in com.hazelcast.multimap.impl
-  
- MultiMapRecord() - Constructor for class com.hazelcast.multimap.impl.MultiMapRecord
-  
- MultiMapRecord(Object) - Constructor for class com.hazelcast.multimap.impl.MultiMapRecord
-  
- MultiMapRecord(long, Object) - Constructor for class com.hazelcast.multimap.impl.MultiMapRecord
-  
- MultiMapRemoveEntryListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_REMOVEENTRYLISTENER
 
- MultiMapRemoveEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryListenerMessageTask
-  
- MultiMapRemoveEntryMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_REMOVEENTRY
 
- MultiMapRemoveEntryMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveEntryMessageTask
-  
- MultiMapRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_REMOVE
 
- MultiMapRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapRemoveMessageTask
-  
- MultiMapRequest - Class in com.hazelcast.multimap.impl.client
-  
- MultiMapRequest() - Constructor for class com.hazelcast.multimap.impl.client.MultiMapRequest
-  
- MultiMapRequest(String) - Constructor for class com.hazelcast.multimap.impl.client.MultiMapRequest
-  
- MultiMapResponse - Class in com.hazelcast.multimap.impl.operations
-  
- MultiMapResponse() - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapResponse
-  
- MultiMapResponse(Collection, MultiMapConfig.ValueCollectionType) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapResponse
-  
- MultiMapService - Class in com.hazelcast.multimap.impl
-  
- MultiMapService(NodeEngine) - Constructor for class com.hazelcast.multimap.impl.MultiMapService
-  
- MultiMapSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_SIZE
 
- MultiMapSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
-  
- MultiMapTransactionLogRecord - Class in com.hazelcast.multimap.impl.txn
-  
- MultiMapTransactionLogRecord() - Constructor for class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
-  
- MultiMapTransactionLogRecord(int, Data, String, long, long) - Constructor for class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
-  
- MultiMapTryLockMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_TRYLOCK
 
- MultiMapTryLockMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapTryLockMessageTask
-  
- MultiMapUnlockMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_UNLOCK
 
- MultiMapUnlockMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapUnlockMessageTask
-  
- MultiMapUnlockRequest - Class in com.hazelcast.multimap.impl.client
-  
- MultiMapUnlockRequest() - Constructor for class com.hazelcast.multimap.impl.client.MultiMapUnlockRequest
-  
- MultiMapUnlockRequest(Data, long, String) - Constructor for class com.hazelcast.multimap.impl.client.MultiMapUnlockRequest
-  
- MultiMapUnlockRequest(Data, long, boolean, String) - Constructor for class com.hazelcast.multimap.impl.client.MultiMapUnlockRequest
-  
- MultiMapValue - Class in com.hazelcast.multimap.impl
- 
The MultiMapValue is the value in a multimap and it contains either a set or a list as collection. 
- MultiMapValue(Collection<MultiMapRecord>) - Constructor for class com.hazelcast.multimap.impl.MultiMapValue
-  
- MultiMapValueCountMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_VALUECOUNT
 
- MultiMapValueCountMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValueCountMessageTask
-  
- MultiMapValuesMessageTask - Class in com.hazelcast.client.impl.protocol.task.multimap
- 
Client Protocol Task for handling messages with type id:
 MultiMapMessageType.MULTIMAP_VALUES
 
- MultiMapValuesMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
-  
- MultiPartitionClientRequest - Class in com.hazelcast.client.impl.client
-  
- MultiPartitionClientRequest() - Constructor for class com.hazelcast.client.impl.client.MultiPartitionClientRequest
-  
- MultipleEntryBackupOperation - Class in com.hazelcast.map.impl.operation
-  
- MultipleEntryBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryBackupOperation
-  
- MultipleEntryBackupOperation(String, Set<Data>, EntryBackupProcessor) - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryBackupOperation
-  
- MultipleEntryOperation - Class in com.hazelcast.map.impl.operation
-  
- MultipleEntryOperation() - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryOperation
-  
- MultipleEntryOperation(String, Set<Data>, EntryProcessor) - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryOperation
-  
- MultipleEntryOperationFactory - Class in com.hazelcast.map.impl.operation
-  
- MultipleEntryOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryOperationFactory
-  
- MultipleEntryOperationFactory(String, Set<Data>, EntryProcessor) - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryOperationFactory
-  
- MultiResult<T> - Class in com.hazelcast.query.impl.getters
- 
Represents multiple results from a single attribute extraction. 
- MultiResult() - Constructor for class com.hazelcast.query.impl.getters.MultiResult
-  
- MultiResult(List<T>) - Constructor for class com.hazelcast.query.impl.getters.MultiResult
-  
- MultiResultSet - Interface in com.hazelcast.query.impl
- 
TODO: 
- MultiTargetClientRequest - Class in com.hazelcast.client.impl.client
- 
Base class for client request that will be send more than one member 
- MultiTargetClientRequest() - Constructor for class com.hazelcast.client.impl.client.MultiTargetClientRequest
-  
- MurmurHash3_fmix(int) - Static method in class com.hazelcast.util.HashUtil
-  
- MurmurHash3_fmix(long) - Static method in class com.hazelcast.util.HashUtil
-  
- MurmurHash3_x64_64(byte[], int, int) - Static method in class com.hazelcast.util.HashUtil
-  
- MurmurHash3_x64_64(byte[], int, int, int) - Static method in class com.hazelcast.util.HashUtil
-  
- MurmurHash3_x64_64_direct(long, int, int) - Static method in class com.hazelcast.util.HashUtil
-  
- MurmurHash3_x64_64_direct(long, int, int, int) - Static method in class com.hazelcast.util.HashUtil
-  
- MurmurHash3_x86_32(byte[], int, int) - Static method in class com.hazelcast.util.HashUtil
-  
- MurmurHash3_x86_32(byte[], int, int, int) - Static method in class com.hazelcast.util.HashUtil
- 
Returns the MurmurHash3_x86_32 hash. 
- MurmurHash3_x86_32_direct(long, int, int) - Static method in class com.hazelcast.util.HashUtil
-  
- MurmurHash3_x86_32_direct(long, int, int, int) - Static method in class com.hazelcast.util.HashUtil
- 
Returns the MurmurHash3_x86_32 hash. 
- MutableInteger - Class in com.hazelcast.util
- 
Mutable integer which can be used for counting purposes. 
- MutableInteger() - Constructor for class com.hazelcast.util.MutableInteger
-  
- MutableLong - Class in com.hazelcast.util
- 
Mutable long which can be used for counting purposes. 
- MutableLong() - Constructor for class com.hazelcast.util.MutableLong
-  
- MutableOperation - Interface in com.hazelcast.cache.impl.operation
-  
- MutatingOperation - Interface in com.hazelcast.spi.impl
- 
Marker interface for operations that changes map state/data. 
- mutex - Variable in class com.hazelcast.cache.impl.CachePartitionSegment
-  
- mutexFor(Object) - Method in class com.hazelcast.util.ContextMutexFactory
-  
- MwCounter - Class in com.hazelcast.util.counters
- 
A  Counter that is thread-safe; so can be incremented by multiple threads concurrently. 
- MXBeansDTO - Class in com.hazelcast.internal.management.dto
- 
Holder class for serializable service beans. 
- MXBeansDTO() - Constructor for class com.hazelcast.internal.management.dto.MXBeansDTO
-  
- MXBeanUtil - Class in com.hazelcast.cache.impl
- 
MXBean utility methods related to registration of the beans. 
- RandomLB - Class in com.hazelcast.client.util
- 
- RandomLB() - Constructor for class com.hazelcast.client.util.RandomLB
-  
- randomPartitionKey() - Method in class com.hazelcast.client.proxy.PartitionServiceProxy
-  
- randomPartitionKey() - Method in interface com.hazelcast.core.PartitionService
- 
Deprecated. 
- randomPartitionKey() - Method in class com.hazelcast.partition.PartitionServiceProxy
-  
- RandomPicker - Class in com.hazelcast.util
- 
User: ahmetmircik
 Date: 10/7/13
 Time: 12:27 PM 
- REACHED_MAX_SIZE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- ReachedMaxSizeException - Exception in com.hazelcast.map
- 
Exception thrown when a write-behind  MapStore rejects to accept a new element. 
- ReachedMaxSizeException(String) - Constructor for exception com.hazelcast.map.ReachedMaxSizeException
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.AbstractCacheRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheAddInvalidationListenerRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheAddPartitionLostListenerRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheClearRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheContainsKeyRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheCreateConfigRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheDestroyRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheEntryProcessorRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheGetAllRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheGetAndRemoveRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheGetAndReplaceRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheGetConfigRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheGetRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheIterateRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheManagementConfigRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CachePutAllRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CachePutIfAbsentRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CachePutRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheRemoveRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheReplaceRequest
-  
- read(PortableReader) - Method in class com.hazelcast.client.impl.client.AuthenticationRequest
-  
- read(PortableReader) - Method in class com.hazelcast.client.impl.client.BaseClientAddListenerRequest
-  
- read(PortableReader) - Method in class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
-  
- read(PortableReader) - Method in class com.hazelcast.client.impl.client.ClientCreateRequest
-  
- read(PortableReader) - Method in class com.hazelcast.client.impl.client.ClientDestroyRequest
-  
- read(PortableReader) - Method in class com.hazelcast.client.impl.client.ClientRequest
-  
- read(PortableReader) - Method in class com.hazelcast.cluster.client.RegisterMembershipListenerRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.collection.client.CollectionAddAllRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.collection.client.CollectionAddListenerRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.collection.client.CollectionAddRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.collection.client.CollectionCompareAndRemoveRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.collection.client.CollectionContainsRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.collection.client.CollectionRemoveListenerRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.collection.client.CollectionRemoveRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.collection.client.CollectionRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.list.client.ListAddAllRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.list.client.ListAddRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.list.client.ListGetRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.list.client.ListIndexOfRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.list.client.ListRemoveRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.list.client.ListSetRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.list.client.ListSubRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.queue.client.AddAllRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.queue.client.AddListenerRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.queue.client.CompareAndRemoveRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.queue.client.ContainsRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.queue.client.DrainRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.queue.client.OfferRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.queue.client.QueueRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.queue.client.RemoveRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.txncollection.client.TxnCollectionRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnOfferRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnPeekRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnPollRequest
-  
- read(PortableReader) - Method in class com.hazelcast.collection.impl.txnqueue.client.TxnSizeRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomiclong.client.ApplyRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomiclong.client.CompareAndSetRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomiclong.client.ReadRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomicreference.client.AbstractAlterRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomicreference.client.ApplyRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomicreference.client.CompareAndSetRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomicreference.client.ContainsRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomicreference.client.ModifyRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomicreference.client.ReadRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.lock.client.AwaitRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.lock.client.BeforeAwaitRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.lock.client.SignalRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.semaphore.client.AcquireRequest
-  
- read(PortableReader) - Method in class com.hazelcast.concurrent.semaphore.client.SemaphoreRequest
-  
- read(PortableReader) - Method in class com.hazelcast.executor.impl.client.CancellationRequest
-  
- read(PortableReader) - Method in class com.hazelcast.executor.impl.client.IsShutdownRequest
-  
- read(PortableReader) - Method in class com.hazelcast.executor.impl.client.PartitionTargetCallableRequest
-  
- read(PortableReader) - Method in class com.hazelcast.executor.impl.client.ShutdownRequest
-  
- read(PortableReader) - Method in class com.hazelcast.executor.impl.client.SpecificTargetCallableRequest
-  
- read() - Method in interface com.hazelcast.internal.metrics.DoubleGauge
- 
Reads the current available value as a double. 
- read() - Method in interface com.hazelcast.internal.metrics.LongGauge
- 
Reads the current available value as a long. 
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ArrayListStreamSerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.BooleanArraySerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.BooleanSerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.ByteSerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.CharArraySerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.CharSerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.DoubleArraySerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.DoubleSerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.FloatArraySerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.FloatSerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.IntegerArraySerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.IntegerSerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.LongArraySerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.LongSerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.NullSerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.ShortArraySerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.ShortSerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.StringArraySerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.StringSerializer
-  
- read(byte[]) - Method in class com.hazelcast.internal.serialization.impl.ConstantSerializers.TheByteArraySerializer
-  
- read(String, ValueCallback) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- read(String, ValueCollector) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- read(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.BigDecimalSerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.BigIntegerSerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.ClassSerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.DateSerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.EnumSerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.ExternalizableSerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.JavaDefaultSerializers.JavaSerializer
-  
- read(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.LinkedListStreamSerializer
-  
- read() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- read(byte[]) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- read(byte[], int, int) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapAddEntryListenerRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapAddEntryListenerSqlRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapAddIndexRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapAddPartitionLostListenerRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapClearNearCacheRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapClearRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapContainsKeyRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapContainsValueRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapDeleteRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapEvictAllRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapEvictRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapFlushRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapGetAllRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapGetRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapIsEmptyRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapIsLockedRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapLockRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapPutAllRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapPutRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapReplaceIfSameRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapSizeRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapTryPutRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-  
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapUnlockRequest
-  
- read(PortableReader) - Method in class com.hazelcast.mapreduce.impl.client.ClientCancellationRequest
-  
- read(PortableReader) - Method in class com.hazelcast.mapreduce.impl.client.ClientJobProcessInformationRequest
-  
- read(PortableReader) - Method in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-  
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-  
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.ContainsRequest
-  
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.CountRequest
-  
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.GetAllRequest
-  
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.KeyBasedContainsRequest
-  
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.MultiMapAllPartitionRequest
-  
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.MultiMapIsLockedRequest
-  
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.MultiMapKeyBasedRequest
-  
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.MultiMapLockRequest
-  
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.MultiMapRequest
-  
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.MultiMapUnlockRequest
-  
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.PutRequest
-  
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.RemoveAllRequest
-  
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.RemoveRequest
-  
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapGetRequest
-  
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapPutRequest
-  
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveAllRequest
-  
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveRequest
-  
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRequest
-  
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapValueCountRequest
-  
- read(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- read(byte[]) - Method in interface com.hazelcast.nio.serialization.ByteArraySerializer
- 
Converts given byte array to object 
- read(ObjectDataInput) - Method in interface com.hazelcast.nio.serialization.StreamSerializer
- 
Reads object from objectDataInputStream 
- read(ByteBuffer) - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-  
- read(ByteBuffer) - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-  
- read() - Method in class com.hazelcast.nio.tcp.spinning.SpinningSocketReader
-  
- read(String, ValueCallback<T>) - Method in class com.hazelcast.query.extractor.ValueReader
- 
Read the value of the attribute specified by the path and returns the result via the callback. 
- read(String, ValueCollector<T>) - Method in class com.hazelcast.query.extractor.ValueReader
- 
Read the value of the attribute specified by the path and returns the result directly to the collector. 
- read(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-  
- read(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
-  
- read(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapClearRequest
-  
- read(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsKeyRequest
-  
- read(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsValueRequest
-  
- read(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapGetRequest
-  
- read(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-  
- read(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutTtlRequest
-  
- read(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveRequest
-  
- read(PortableReader) - Method in class com.hazelcast.ringbuffer.impl.client.AddAllRequest
-  
- read(PortableReader) - Method in class com.hazelcast.ringbuffer.impl.client.AddRequest
-  
- read(PortableReader) - Method in class com.hazelcast.ringbuffer.impl.client.ReadManyRequest
-  
- read(PortableReader) - Method in class com.hazelcast.ringbuffer.impl.client.ReadOneRequest
-  
- read(PortableReader) - Method in class com.hazelcast.ringbuffer.impl.client.RingbufferRequest
-  
- read(long) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-  
- read(PortableReader) - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-  
- read(PortableReader) - Method in class com.hazelcast.topic.impl.client.PublishRequest
-  
- read(PortableReader) - Method in class com.hazelcast.transaction.client.BaseTransactionRequest
-  
- read(PortableReader) - Method in class com.hazelcast.transaction.client.BaseXATransactionRequest
-  
- read(PortableReader) - Method in class com.hazelcast.transaction.client.ClearRemoteTransactionRequest
-  
- read(PortableReader) - Method in class com.hazelcast.transaction.client.CommitXATransactionRequest
-  
- read(PortableReader) - Method in class com.hazelcast.transaction.client.CreateTransactionRequest
-  
- read(PortableReader) - Method in class com.hazelcast.transaction.client.CreateXATransactionRequest
-  
- read(PortableReader) - Method in class com.hazelcast.transaction.client.FinalizeXATransactionRequest
-  
- READ_MANY - Static variable in class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
-  
- READ_MANY_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
-  
- READ_ONE - Static variable in class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
-  
- READ_ONE_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
-  
- READ_RESULT_SET - Static variable in class com.hazelcast.client.impl.protocol.ResponseMessageConst
-  
- READ_RESULT_SET - Static variable in class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
-  
- READ_RESULT_SET - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
-  
- readAttributeValue(ObjectDataInput) - Static method in class com.hazelcast.nio.IOUtil
-  
- readAttributeValue(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
-  
- readBackupData(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- readBackupData(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
- 
Called when  MapConfig.isReadBackupData() is  true from
  MapProxySupport.getInternal(com.hazelcast.nio.serialization.Data)
 Returns corresponding value for key as  Data. 
- readBoolean(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- readBoolean(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- readBoolean() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readBoolean(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- readBoolean(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- readBooleanArray(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- readBooleanArray(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- readBooleanArray() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readBooleanArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-  
- readBooleanArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- readByte(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- readByte(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- readByte() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readByte(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- readByte(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- readByteArray(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- readByteArray(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- readByteArray() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readByteArray(ObjectDataInput) - Static method in class com.hazelcast.nio.IOUtil
-  
- readByteArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-  
- readByteArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- readChar(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- readChar(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- readChar() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readChar(byte[], int, boolean) - Static method in class com.hazelcast.nio.Bits
-  
- readChar(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- readChar(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- readCharArray(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- readCharArray(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- readCharArray() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readCharArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-  
- readCharArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- readCharB(byte[], int) - Static method in class com.hazelcast.nio.Bits
-  
- readCharL(byte[], int) - Static method in class com.hazelcast.nio.Bits
-  
- readCount() - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
-  
- readCount() - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
-  
- readCount() - Method in interface com.hazelcast.ringbuffer.ReadResultSet
- 
Returns the number of items that have been read before filtering. 
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.CacheClearResponse
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.CacheEventSet
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.CacheKeyIteratorResult
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.CachePartitionEventData
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.event.CachePartitionLostEventFilter
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.merge.entry.DefaultCacheEntryView
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.record.CacheDataRecord
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.record.CacheObjectRecord
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.client.impl.client.ClientResponse
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.client.impl.operations.OperationFactoryWrapper
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cluster.client.ClientInitialMembershipEvent
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cluster.client.ClientMembershipEvent
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cluster.client.MemberAttributeChange
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.BindMessage
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.ClusterStateTransactionLogRecord
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.ConfigCheck
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.JoinMessage
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.JoinRequest
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.cluster.MemberInfo
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.CollectionEvent
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.CollectionEventFilter
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.CollectionItem
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.TxCollectionItem
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.QueueEvent
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.QueueEventFilter
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.QueueItem
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.QueueTransactionLogRecord
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.TxQueueItem
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.InternalLockNamespace
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.config.EvictionConfig
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.config.MaxSizeConfig
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.config.NearCacheConfig
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.config.WanReplicationRef
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.console.Echo
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.core.MemberAttributeEvent
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.core.MigrationEvent
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.core.PartitionAwareKey
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.executor.impl.RunnableAdapter
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.hibernate.distributed.LockEntryProcessor
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.hibernate.distributed.UnlockEntryProcessor
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.hibernate.distributed.UpdateEntryProcessor
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.hibernate.local.Invalidation
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.hibernate.local.Timestamp
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.hibernate.serialization.Expirable
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.hibernate.serialization.ExpiryMarker
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.hibernate.serialization.Value
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.hibernate.VersionAwareMapMergePolicy
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.instance.AbstractMember
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.internal.ascii.memcache.MemcacheEntry
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.internal.ascii.rest.RestValue
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.internal.management.dto.MapConfigDTO
-  
- readData() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.EntryEventFilter
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.event.EntryEventData
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.event.MapEventData
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.event.MapPartitionEventData
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.EventListenerFilter
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.MapEntries
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.MapKeySet
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.MapPartitionLostEventFilter
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.MapValueCollection
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.nearcache.BatchNearCacheInvalidation
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.nearcache.Invalidation
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.nearcache.SingleNearCacheInvalidation
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.AddIndexOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.ClearOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.ContainsValueOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.EvictAllOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.IsEmptyOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.LoadStatusOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapFlushOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapGetAllOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapLoadAllOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionCheckIfLoadedOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.SizeOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.query.QueryEventFilter
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.query.QueryResult
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.query.QueryResultRow
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.record.EmptyRecordStatistics
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.record.RecordInfo
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.record.RecordReplicationInfo
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.record.RecordStatisticsImpl
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.MapTransactionLogRecord
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.VersionedValue
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.merge.HigherHitsMapMergePolicy
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.merge.LatestUpdateMapMergePolicy
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.merge.PassThroughMergePolicy
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.map.merge.PutIfAbsentMapMergePolicy
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.aggregation.impl.AcceptAllSupplier
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.aggregation.impl.AvgTuple
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.aggregation.impl.KeyPredicateSupplier
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.aggregation.impl.PredicateSupplier
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.aggregation.impl.SetAdapter
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.CombinerResultList
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.HashMapAdapter
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.ListKeyValueSource
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.MapKeyValueSource
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.MultiMapKeyValueSource
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.notification.IntermediateChunkNotification
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.notification.LastChunkNotification
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.notification.MapReduceNotification
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.notification.MemberAwareMapReduceNotification
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.notification.ReducingFinishedNotification
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.GetResultOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentResult
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionResult
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.SetKeyValueSource
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.task.JobPartitionStateImpl
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.MultiMapEventFilter
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.MultiMapRecord
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.EntrySetResponse
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.nio.Address
-  
- readData() - Method in interface com.hazelcast.nio.ObjectDataInput
-  
- readData(ObjectDataInput) - Method in interface com.hazelcast.nio.serialization.DataSerializable
- 
Reads fields from the input stream 
- readData(ObjectDataInput) - Method in class com.hazelcast.partition.client.PartitionsResponse
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.partition.InternalPartitionLostEvent
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.partition.MigrationInfo
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.partition.PartitionLostEvent
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.partition.PartitionRuntimeState
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.FalsePredicate
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.IndexImpl.NullObject
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.AndPredicate
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.BetweenPredicate
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.EqualPredicate
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.InPredicate
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.InstanceOfPredicate
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.LikePredicate
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.NotPredicate
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.OrPredicate
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.predicates.RegexPredicate
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.query.PagingPredicate
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.query.PredicateBuilder
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.query.SqlPredicate
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.query.TruePredicate
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.PutAllOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.VersionResponsePair
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.DefaultObjectNamespace
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.BinaryOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventEnvelope
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.eventservice.impl.TrueEventFilter
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation.PartitionResponse
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.ErrorResponse
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.NormalResponse
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.proxyservice.impl.DistributedObjectEventPacket
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.SerializableList
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.Operation
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicMessage
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.topic.impl.TopicEvent
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.xa.operations.CollectRemoteTransactionsOperationFactory
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.xa.SerializableXID
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.xa.XATransactionDTO
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.transaction.TransactionOptions
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.wan.WanReplicationEvent
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.web.entryprocessor.DeleteSessionEntryProcessor
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.web.entryprocessor.GetAttributeEntryProcessor
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.web.entryprocessor.GetAttributeNamesEntryProcessor
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.web.entryprocessor.GetSessionStateEntryProcessor
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.web.entryprocessor.SessionUpdateEntryProcessor
-  
- readData(ObjectDataInput) - Method in class com.hazelcast.web.SessionState
-  
- readDataInner(ObjectDataInput) - Method in class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-  
- readDataInner(ObjectDataInput) - Method in class com.hazelcast.map.impl.client.TxnMapRequest
-  
- readDataInner(ObjectDataInput) - Method in class com.hazelcast.map.impl.client.TxnMapRequestWithSQLQuery
-  
- readDouble(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- readDouble(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- readDouble() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readDouble(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- readDouble(ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- readDouble(int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- readDouble(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- readDoubleArray(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- readDoubleArray(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- readDoubleArray() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readDoubleArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-  
- readDoubleArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- readFloat(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- readFloat(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- readFloat() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readFloat(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- readFloat(ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- readFloat(int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- readFloat(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- readFloatArray(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- readFloatArray(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- readFloatArray() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readFloatArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-  
- readFloatArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- readFrom(ByteBuffer) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
-  
- readFrom(DataInput) - Static method in enum com.hazelcast.core.MigrationEvent.MigrationStatus
-  
- readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.DeleteCommand
-  
- readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.ErrorCommand
-  
- readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.GetCommand
-  
- readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.IncrementCommand
-  
- readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.SetCommand
-  
- readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.SimpleCommand
-  
- readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.StatsCommand
-  
- readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.TouchCommand
-  
- readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.memcache.VersionCommand
-  
- readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.NoOpCommand
-  
- readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.rest.HttpDeleteCommand
-  
- readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.rest.HttpGetCommand
-  
- readFrom(ByteBuffer) - Method in class com.hazelcast.internal.ascii.rest.HttpPostCommand
- 
POST /path HTTP/1.0
 User-Agent: HTTPTool/1.0
 Content-TextCommandType: application/x-www-form-urlencoded
 Content-Length: 45
 
 
 byte[45]
  
- readFrom(ByteBuffer) - Method in interface com.hazelcast.internal.ascii.TextCommand
-  
- readFrom(ByteBuffer) - Method in class com.hazelcast.nio.Packet
-  
- readFrom(DataInput) - Static method in enum com.hazelcast.partition.MigrationEndpoint
-  
- readFully(byte[]) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readFully(byte[], int, int) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- ReadHandler - Interface in com.hazelcast.nio.tcp
- 
- readInt(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- readInt(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- readInt() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readInt(byte[], int, boolean) - Static method in class com.hazelcast.nio.Bits
-  
- readInt(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- readInt(ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- readInt(int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- readInt(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- readIntArray(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- readIntArray(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- readIntArray() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readIntArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-  
- readIntArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- readIntB(byte[], int) - Static method in class com.hazelcast.nio.Bits
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheDestroyOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheGetOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheKeyIteratorOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CachePutBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.PostJoinCacheOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.client.impl.operations.ClientDisconnectionOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.client.impl.operations.ClientReAuthOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.client.impl.operations.PostJoinClientOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.AuthorizationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.BeforeJoinCheckFailureOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.ChangeClusterStateOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.ConfigMismatchOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.FinalizeJoinOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.HeartbeatOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.JoinCheckOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.JoinRequestOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.LockClusterStateOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.MasterConfirmationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.MasterDiscoveryOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.MemberAttributeChangedOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.MemberInfoUpdateOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.MemberRemoveOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.MergeClustersOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.PostJoinOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.RollbackClusterStateOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.SetMasterOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionClearBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionCompareAndRemoveOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionContainsOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.list.operations.ListAddAllOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.list.operations.ListAddOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.list.operations.ListGetOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.list.operations.ListIndexOfOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.list.operations.ListRemoveOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.list.operations.ListReplicationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.list.operations.ListSetBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.list.operations.ListSetOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.list.operations.ListSubOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.AddAllBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.AddAllOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.ClearBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.ContainsOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.DrainBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.DrainOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.OfferBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.PollBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.QueueOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.QueueReplicationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.RemoveBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.queue.operations.RemoveOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.set.operations.SetReplicationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveAddOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveRemoveOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTransactionRollbackOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.QueueTransactionRollbackOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPeekOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.SetBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.SetOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.SetBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.SetOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.AwaitBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.BaseLockOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.LocalLockCleanupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.LockBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.UnlockBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.UnlockIfLeaseExpiredOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.management.operation.GetMapConfigOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.management.operation.ScriptExecutorOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.management.operation.ThreadDumpOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.management.operation.UpdateManagementCenterUrlOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.internal.management.operation.UpdateMapConfigOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.AddIndexOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.ClearExpiredOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.ContainsValueOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.EntryBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.EntryOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.EvictOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.GetAllOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.LoadAllOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.LoadMapOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.LoadStatusOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapReplicationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MergeOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MultipleEntryBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.NearCacheBatchInvalidationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.NearCacheSingleInvalidationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionCheckIfLoadedOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PutAllBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PutAllOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.RemoveBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.RemoveIfSameOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.query.QueryOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.query.QueryPartitionOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnLockAndGetOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnPrepareBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnRollbackBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnUnlockBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.CancelJobSupervisorOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.FireNotificationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.KeyValueJobOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.NotifyRemoteExceptionOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.PostPonePartitionProcessing
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.ProcessingOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.ProcessStatsUpdateOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionProcessed
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionReducing
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.StartProcessingJobOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.MultiMapBackupAwareOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.MultiMapMigrationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.PutBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.PutOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.RemoveBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.RemoveOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnCommitBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnPutBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.partition.impl.BaseMigrationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.partition.impl.CheckReplicaVersion
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.partition.impl.IsReplicaVersionSync
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.partition.impl.MigrationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.partition.impl.PartitionStateOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.partition.impl.ReplicaSyncRequest
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.partition.impl.ReplicaSyncResponse
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.partition.impl.ReplicaSyncRetryResponse
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.CheckReplicaVersion
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.ContainsKeyOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.ContainsValueOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.EntrySetOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.GetOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.IsEmptyOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.KeySetOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.MergeOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.PutAllOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.PutOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.RemoveOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateToCallerOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.RequestMapDataOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.SizeOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.SyncReplicatedMapDataOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.ValuesOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.operations.AbstractRingBufferOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.operations.AddBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.operations.GenericOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.operations.ReadManyOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.operations.ReadOneOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.ringbuffer.impl.operations.ReplicationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.AbstractOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.AbstractNamedOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.DeregistrationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.PostJoinRegistrationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.RegistrationOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.SendEventOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.IsStillExecutingOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.TraceableIsStillExecutingOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.DistributedObjectDestroyOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.InitializeDistributedObjectOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.PostJoinProxyOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.Operation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.topic.impl.PublishOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.operations.BroadcastTxRollbackOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.operations.PurgeTxBackupLogOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.operations.ReplicateTxBackupLogOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.operations.RollbackTxBackupLogOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionBackupOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionOperation
-  
- readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.xa.operations.XaReplicationOperation
-  
- readIntL(byte[], int) - Static method in class com.hazelcast.nio.Bits
-  
- readLine() - Method in interface com.hazelcast.console.LineReader
-  
- readLine() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
- 
Deprecated. 
- readLock - Variable in class com.hazelcast.query.impl.BaseIndexStore
-  
- readLong(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- readLong(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- readLong() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readLong(byte[], int, boolean) - Static method in class com.hazelcast.nio.Bits
-  
- readLong(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- readLong(ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- readLong(int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- readLong(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- readLongArray(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- readLongArray(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- readLongArray() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readLongArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-  
- readLongArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- readLongAttribute(String, long) - Static method in class com.hazelcast.util.OperatingSystemMXBeanSupport
- 
Reads a long attribute from OperatingSystemMXBean. 
- readLongB(byte[], int) - Static method in class com.hazelcast.nio.Bits
-  
- readLongL(byte[], int) - Static method in class com.hazelcast.nio.Bits
-  
- readMany(long, ReadResultSetImpl) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-  
- readManyAsync(long, int, int, IFunction<E, Boolean>) - Method in class com.hazelcast.client.proxy.ClientRingbufferProxy
-  
- readManyAsync(long, int, int, IFunction<E, Boolean>) - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
-  
- readManyAsync(long, int, int, IFunction<E, Boolean>) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
- 
Reads a batch of items from the Ringbuffer. 
- ReadManyOperation - Class in com.hazelcast.ringbuffer.impl.operations
-  
- ReadManyOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.ReadManyOperation
-  
- ReadManyOperation(String, long, int, int, IFunction<?, Boolean>) - Constructor for class com.hazelcast.ringbuffer.impl.operations.ReadManyOperation
-  
- ReadManyOperation(String, long, int, int, IFunction<?, Boolean>, boolean) - Constructor for class com.hazelcast.ringbuffer.impl.operations.ReadManyOperation
-  
- ReadManyRequest - Class in com.hazelcast.ringbuffer.impl.client
-  
- ReadManyRequest() - Constructor for class com.hazelcast.ringbuffer.impl.client.ReadManyRequest
-  
- ReadManyRequest(String, long, int, int, Data) - Constructor for class com.hazelcast.ringbuffer.impl.client.ReadManyRequest
-  
- readObject(ObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- readObject() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readObject(ObjectDataInput) - Method in interface com.hazelcast.internal.serialization.SerializationService
-  
- readObject(ObjectDataInput) - Static method in class com.hazelcast.nio.IOUtil
-  
- readObject() - Method in interface com.hazelcast.nio.ObjectDataInput
-  
- readOne(long) - Method in class com.hazelcast.client.proxy.ClientRingbufferProxy
-  
- readOne(long) - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
-  
- readOne(long) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
- 
Reads one item from the Ringbuffer. 
- ReadOneOperation - Class in com.hazelcast.ringbuffer.impl.operations
-  
- ReadOneOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.ReadOneOperation
-  
- ReadOneOperation(String, long) - Constructor for class com.hazelcast.ringbuffer.impl.operations.ReadOneOperation
-  
- ReadOneRequest - Class in com.hazelcast.ringbuffer.impl.client
-  
- ReadOneRequest() - Constructor for class com.hazelcast.ringbuffer.impl.client.ReadOneRequest
-  
- ReadOneRequest(String, long) - Constructor for class com.hazelcast.ringbuffer.impl.client.ReadOneRequest
-  
- readOnly - Variable in class com.hazelcast.config.EvictionConfig
-  
- ReadOnlyAccessDelegate<T extends HazelcastRegion> - Class in com.hazelcast.hibernate.access
- 
Guarantees that view is read-only and no updates can be made 
- ReadOnlyAccessDelegate(T, Properties) - Constructor for class com.hazelcast.hibernate.access.ReadOnlyAccessDelegate
-  
- ReadonlyOperation - Interface in com.hazelcast.spi
- 
Read-only operations are not retried during migration. 
- readPortable(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheBatchInvalidationMessage
-  
- readPortable(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheInvalidationMessage
-  
- readPortable(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheSingleInvalidationMessage
-  
- readPortable(PortableReader) - Method in class com.hazelcast.client.impl.client.ClientPrincipal
-  
- readPortable(PortableReader) - Method in class com.hazelcast.client.impl.client.ClientRequest
-  
- readPortable(PortableReader) - Method in class com.hazelcast.client.impl.client.DistributedObjectInfo
-  
- readPortable(PortableReader) - Method in class com.hazelcast.client.impl.client.GenericError
-  
- readPortable(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- readPortable(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- readPortable(PortableReader) - Method in class com.hazelcast.mapreduce.impl.task.TransferableJobProcessInformation
-  
- readPortable(PortableReader) - Method in class com.hazelcast.multimap.impl.client.PortableEntrySetResponse
-  
- readPortable(PortableReader) - Method in interface com.hazelcast.nio.serialization.Portable
- 
Read portable fields using PortableReader 
- readPortable(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- readPortable(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
-  
- readPortable(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeys
-  
- readPortable(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-  
- readPortable(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapValueCollection
-  
- readPortable(PortableReader) - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
-  
- readPortable(PortableReader) - Method in class com.hazelcast.security.AbstractCredentials
-  
- readPortable(PortableReader) - Method in class com.hazelcast.spi.impl.PortableCachePartitionLostEvent
-  
- readPortable(PortableReader) - Method in class com.hazelcast.spi.impl.PortableCollection
-  
- readPortable(PortableReader) - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
-  
- readPortable(PortableReader) - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-  
- readPortable(PortableReader) - Method in class com.hazelcast.spi.impl.PortableItemEvent
-  
- readPortable(PortableReader) - Method in class com.hazelcast.spi.impl.PortableMapPartitionLostEvent
-  
- readPortable(PortableReader) - Method in class com.hazelcast.spi.impl.PortablePartitionLostEvent
-  
- readPortable(PortableReader) - Method in class com.hazelcast.topic.impl.client.PortableMessage
-  
- readPortableArray(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- readPortableArray(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- readPortableArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- readPortableInner(PortableReader) - Method in class com.hazelcast.map.impl.client.MapQueryRequest
-  
- readPortableInner(PortableReader) - Method in class com.hazelcast.map.impl.client.MapSQLQueryRequest
-  
- readPortableInternal(PortableReader) - Method in class com.hazelcast.security.AbstractCredentials
-  
- readPortableInternal(PortableReader) - Method in class com.hazelcast.security.UsernamePasswordCredentials
-  
- ReadRequest - Class in com.hazelcast.concurrent.atomiclong.client
-  
- ReadRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.ReadRequest
-  
- ReadRequest(String) - Constructor for class com.hazelcast.concurrent.atomiclong.client.ReadRequest
-  
- ReadRequest - Class in com.hazelcast.concurrent.atomicreference.client
-  
- ReadRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.ReadRequest
-  
- ReadRequest(String) - Constructor for class com.hazelcast.concurrent.atomicreference.client.ReadRequest
-  
- readResponse(JsonObject) - Method in class com.hazelcast.internal.management.request.ChangeClusterStateRequest
-  
- readResponse(JsonObject) - Method in class com.hazelcast.internal.management.request.ChangeWanStateRequest
-  
- readResponse(JsonObject) - Method in class com.hazelcast.internal.management.request.ClusterPropsRequest
-  
- readResponse(JsonObject) - Method in class com.hazelcast.internal.management.request.ConsoleCommandRequest
-  
- readResponse(JsonObject) - Method in interface com.hazelcast.internal.management.request.ConsoleRequest
-  
- readResponse(JsonObject) - Method in class com.hazelcast.internal.management.request.ExecuteScriptRequest
-  
- readResponse(JsonObject) - Method in class com.hazelcast.internal.management.request.ForceStartNodeRequest
-  
- readResponse(JsonObject) - Method in class com.hazelcast.internal.management.request.GetClusterStateRequest
-  
- readResponse(JsonObject) - Method in class com.hazelcast.internal.management.request.GetLogsRequest
- 
Deprecated. 
- readResponse(JsonObject) - Method in class com.hazelcast.internal.management.request.GetMapEntryRequest
-  
- readResponse(JsonObject) - Method in class com.hazelcast.internal.management.request.GetMemberSystemPropertiesRequest
-  
- readResponse(JsonObject) - Method in class com.hazelcast.internal.management.request.GetSystemWarningsRequest
- 
Deprecated. 
- readResponse(JsonObject) - Method in class com.hazelcast.internal.management.request.MapConfigRequest
-  
- readResponse(JsonObject) - Method in class com.hazelcast.internal.management.request.MemberConfigRequest
-  
- readResponse(JsonObject) - Method in class com.hazelcast.internal.management.request.RunGcRequest
-  
- readResponse(JsonObject) - Method in class com.hazelcast.internal.management.request.ShutdownClusterRequest
-  
- readResponse(JsonObject) - Method in class com.hazelcast.internal.management.request.ShutdownMemberRequest
-  
- readResponse(JsonObject) - Method in class com.hazelcast.internal.management.request.ThreadDumpRequest
-  
- ReadResultSet<E> - Interface in com.hazelcast.ringbuffer
- 
- ReadResultSetImpl<E> - Class in com.hazelcast.ringbuffer.impl
- 
- ReadResultSetImpl() - Constructor for class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
-  
- ReadResultSetImpl(int, int, HazelcastInstance, IFunction<Object, Boolean>) - Constructor for class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
-  
- readShort(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- readShort(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- readShort() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readShort(byte[], int, boolean) - Static method in class com.hazelcast.nio.Bits
-  
- readShort(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- readShort(ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- readShort(int, ByteOrder) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- readShort(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- readShortArray(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- readShortArray(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- readShortArray() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readShortArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-  
- readShortArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- readShortB(byte[], int) - Static method in class com.hazelcast.nio.Bits
-  
- readShortL(byte[], int) - Static method in class com.hazelcast.nio.Bits
-  
- readThroughCache(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- readThroughRecord(Data, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- readUnsignedByte() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readUnsignedShort() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readUTF(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- readUTF(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- readUTF() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readUTF(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- readUtf8Char(byte[], int, char[], int) - Static method in class com.hazelcast.nio.Bits
-  
- readUtf8Char(DataInput, byte) - Static method in class com.hazelcast.nio.Bits
-  
- readUTFArray(String) - Method in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- readUTFArray(String) - Method in class com.hazelcast.internal.serialization.impl.MorphingPortableReader
-  
- readUTFArray() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- readUTFArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-  
- readUTFArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-  
- ReadWriteAccessDelegate<T extends HazelcastRegion> - Class in com.hazelcast.hibernate.access
- 
Makes READ COMMITTED consistency guarantees even in a clustered environment. 
- ReadWriteAccessDelegate(T, Properties) - Constructor for class com.hazelcast.hibernate.access.ReadWriteAccessDelegate
-  
- reArrange(Collection<MemberGroup>, InternalPartition[]) - Method in interface com.hazelcast.partition.impl.PartitionStateGenerator
- 
Rearranges the partition layout. 
- reArrange(Collection<MemberGroup>, InternalPartition[]) - Method in class com.hazelcast.partition.impl.PartitionStateGeneratorImpl
-  
- record - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-  
- Record<V> - Interface in com.hazelcast.map.impl.record
-  
- RecordFactory<T> - Interface in com.hazelcast.map.impl.record
- 
Factory for creating records. 
- recordFactory - Variable in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-  
- recordFactoryConstructor - Variable in class com.hazelcast.map.impl.MapContainer
-  
- RecordInfo - Class in com.hazelcast.map.impl.record
- 
Record info. 
- RecordInfo() - Constructor for class com.hazelcast.map.impl.record.RecordInfo
-  
- RecordInfo(RecordInfo) - Constructor for class com.hazelcast.map.impl.record.RecordInfo
-  
- recordIterator() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-  
- recordIterator() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- recordLoaded - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-  
- RecordMigrationInfo - Class in com.hazelcast.replicatedmap.impl.record
-  
- RecordMigrationInfo() - Constructor for class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
-  
- RecordMigrationInfo(Data, Data, long) - Constructor for class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
-  
- RecordReplicationInfo - Class in com.hazelcast.map.impl.record
-  
- RecordReplicationInfo(Data, Data, RecordInfo) - Constructor for class com.hazelcast.map.impl.record.RecordReplicationInfo
-  
- RecordReplicationInfo() - Constructor for class com.hazelcast.map.impl.record.RecordReplicationInfo
-  
- records - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- records - Variable in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- Records - Class in com.hazelcast.map.impl.record
- 
Contains various factory & helper methods for a  Record object. 
- RecordStatistics - Interface in com.hazelcast.map.impl.record
- 
Represents statistics of a  Record. 
- RecordStatisticsImpl - Class in com.hazelcast.map.impl.record
- 
- RecordStatisticsImpl() - Constructor for class com.hazelcast.map.impl.record.RecordStatisticsImpl
-  
- recordStore - Variable in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-  
- RecordStore<R extends Record> - Interface in com.hazelcast.map.impl.recordstore
- 
Defines a record-store. 
- recordStoreIterator() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-  
- recordStoreLoader - Variable in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- recordStores - Variable in class com.hazelcast.cache.impl.CachePartitionSegment
-  
- recordToData(R) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- recordToData(CacheRecord) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-  
- recordToValue(R) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- recordToValue(CacheRecord) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-  
- recordToValue(R) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- recordToValue(NearCacheDataRecord) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.NearCacheDataRecordStore
-  
- recordToValue(NearCacheObjectRecord) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.NearCacheObjectRecordStore
-  
- recover(int) - Method in class com.hazelcast.client.proxy.txn.xa.XAResourceProxy
-  
- recover(int) - Method in class com.hazelcast.client.txn.proxy.xa.XAResourceProxy
-  
- recover(int) - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.cache.impl.client.CacheClearRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.cache.impl.client.CacheGetAllRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.cache.impl.client.CacheSizeRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.client.AllPartitionsClientRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.client.MultiPartitionClientRequest
-  
- reduce(Map<Address, Object>) - Method in class com.hazelcast.client.impl.client.MultiTargetClientRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.AbstractAllPartitionsMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMultiPartitionMessageTask
-  
- reduce(Map<Address, Object>) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMultiTargetMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheGetAllMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheSizeMessageTask
-  
- reduce(Collection<QueryResultRow>) - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapQueryMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddIndexMessageTask
-  
- reduce(Map<Address, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddInterceptorMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapClearMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapContainsValueMessageTask
-  
- reduce(Collection<QueryResultRow>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPagingPredicateMessageTask
-  
- reduce(Collection<QueryResultRow>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntriesWithPredicateMessageTask
-  
- reduce(Collection<QueryResultRow>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEntrySetMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapEvictAllMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnAllKeysMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteOnKeysMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapExecuteWithPredicateMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
-  
- reduce(Collection<QueryResultRow>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
-  
- reduce(Collection<QueryResultRow>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPagingPredicateMessageTask
-  
- reduce(Collection<QueryResultRow>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
-  
- reduce(Map<Address, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveInterceptorMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapSizeMessageTask
-  
- reduce(Collection<QueryResultRow>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesMessageTask
-  
- reduce(Collection<QueryResultRow>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPagingPredicateMessageTask
-  
- reduce(Collection<QueryResultRow>) - Method in class com.hazelcast.client.impl.protocol.task.map.MapValuesWithPredicateMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapClearMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapContainsValueMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapEntrySetMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapKeySetMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapSizeMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapValuesMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
-  
- reduce(Map<Address, Object>) - Method in class com.hazelcast.client.impl.protocol.task.transaction.XACollectTransactionsMessageTask
-  
- reduce(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-  
- reduce(int) - Method in class com.hazelcast.jmx.SemaphoreMBean
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapAddIndexRequest
-  
- reduce(Map<Address, Object>) - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapClearRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapContainsValueRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapEvictAllRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapFlushRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapIsEmptyRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-  
- reduce(Map<Address, Object>) - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapSizeRequest
-  
- reduce(ValueIn) - Method in class com.hazelcast.mapreduce.Reducer
- 
This method is called to supply values to be reduced into a final reduced result.
 The reduce method might be called multiple times so the eventually reduced value
 needs to be held internally in a member state of the Reducer.
 
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.multimap.impl.client.ClearRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.multimap.impl.client.ContainsRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.multimap.impl.client.EntrySetRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.multimap.impl.client.KeySetRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.multimap.impl.client.SizeRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.multimap.impl.client.ValuesRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapClearRequest
-  
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-  
- reduce(Map<Address, Object>) - Method in class com.hazelcast.transaction.client.CollectXATransactionsRequest
-  
- REDUCE_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-  
- REDUCE_EVERYTHING - Static variable in class com.hazelcast.query.impl.getters.AbstractMultiValueGetter
-  
- REDUCE_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-  
- ReduceBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
-  
- ReduceBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReduceBackupOperation
-  
- ReduceBackupOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReduceBackupOperation
-  
- reduceCollectionInto(MultiResult, Collection) - Method in class com.hazelcast.query.impl.getters.AbstractMultiValueGetter
-  
- reduceInto(MultiResult, Object) - Method in class com.hazelcast.query.impl.getters.AbstractMultiValueGetter
-  
- ReduceOperation - Class in com.hazelcast.concurrent.semaphore.operations
-  
- ReduceOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
-  
- ReduceOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
-  
- reducePermits(int) - Method in class com.hazelcast.client.proxy.ClientSemaphoreProxy
-  
- reducePermits(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-  
- reducePermits(int) - Method in interface com.hazelcast.core.ISemaphore
- 
Shrinks the number of available permits by the indicated
 reduction. 
- reducer(ReducerFactory<? super Key, ? super Value, ? extends ValueOut>) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.MappingJobImpl
-  
- reducer(ReducerFactory<Key, Value, ValueOut>) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.ReducingJobImpl
-  
- reducer(ReducerFactory<? super KeyIn, ? super ValueIn, ? extends ValueOut>) - Method in interface com.hazelcast.mapreduce.MappingJob
- 
- Reducer<ValueIn,ValueOut> - Class in com.hazelcast.mapreduce
- 
 The abstract Reducer class is used to build reducers for the  Job. 
 Reducers may be distributed inside of the cluster but there is always only one Reducer
 per key. 
- Reducer() - Constructor for class com.hazelcast.mapreduce.Reducer
-  
- reducer(ReducerFactory<KeyIn, ValueIn, ValueOut>) - Method in interface com.hazelcast.mapreduce.ReducingJob
- 
- REDUCER_ANY_TOKEN - Static variable in class com.hazelcast.query.impl.getters.AbstractMultiValueGetter
-  
- REDUCER_CHUNK_MESSAGE - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-  
- REDUCER_LAST_CHUNK_MESSAGE - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-  
- ReduceRequest - Class in com.hazelcast.concurrent.semaphore.client
-  
- ReduceRequest() - Constructor for class com.hazelcast.concurrent.semaphore.client.ReduceRequest
-  
- ReduceRequest(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.client.ReduceRequest
-  
- reducerFactory - Variable in class com.hazelcast.mapreduce.impl.AbstractJob
-  
- reducerFactory - Variable in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-  
- ReducerFactory<KeyIn,ValueIn,ValueOut> - Interface in com.hazelcast.mapreduce
- 
A ReducerFactory implementation is used to build  Reducer instances per key. 
 An implementation needs to be serializable by Hazelcast since it might be distributed
 inside the cluster to do parallel calculations for reducing. 
- ReducerTask<Key,Chunk> - Class in com.hazelcast.mapreduce.impl.task
- 
This task implementation executes the reducing phase. 
- ReducerTask(String, String, JobSupervisor) - Constructor for class com.hazelcast.mapreduce.impl.task.ReducerTask
-  
- reducerTasks - Variable in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-  
- REDUCING_FINISHED_MESSAGE - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-  
- ReducingFinishedNotification - Class in com.hazelcast.mapreduce.impl.notification
- 
This notification class is used to signal the  JobSupervisor
 owner node that a reducer has finished the reducing step for the defined partitionId. 
- ReducingFinishedNotification() - Constructor for class com.hazelcast.mapreduce.impl.notification.ReducingFinishedNotification
-  
- ReducingFinishedNotification(Address, String, String, int) - Constructor for class com.hazelcast.mapreduce.impl.notification.ReducingFinishedNotification
-  
- ReducingJob<EntryKey,KeyIn,ValueIn> - Interface in com.hazelcast.mapreduce
- 
 This interface describes a reducing mapreduce Job. 
 For further information  Job. 
- ReducingSubmittableJob<EntryKey,KeyIn,ValueIn> - Interface in com.hazelcast.mapreduce
- 
 This interface describes a submittable mapreduce Job. 
 For further information  Job. 
- REFERENCE_COST_IN_BYTES - Static variable in interface com.hazelcast.map.impl.SizeEstimator
- 
Assume compressed object reference is used. 
- REFERENCE_SIZE - Static variable in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- ReflectionHelper - Class in com.hazelcast.query.impl.getters
- 
Scans your classpath, indexes the metadata, allows you to query it on runtime. 
- refresh() - Method in interface com.hazelcast.client.connection.AddressTranslator
- 
Refreshes the internal lookup table if necessary. 
- refresh() - Method in class com.hazelcast.client.spi.impl.AwsAddressTranslator
-  
- refresh() - Method in class com.hazelcast.client.spi.impl.DefaultAddressTranslator
-  
- refresh() - Method in class com.hazelcast.client.spi.impl.discovery.DiscoveryAddressTranslator
-  
- refreshPartitions() - Method in class com.hazelcast.client.spi.impl.ClientPartitionServiceImpl
-  
- regex(String, String) - Static method in class com.hazelcast.query.Predicates
-  
- REGEX_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
-  
- RegexConfigPatternMatcher - Class in com.hazelcast.config.matcher
- 
This ConfigPatternMatcheruses Java regular expressions for matching.
 
- RegexConfigPatternMatcher() - Constructor for class com.hazelcast.config.matcher.RegexConfigPatternMatcher
-  
- RegexConfigPatternMatcher(int) - Constructor for class com.hazelcast.config.matcher.RegexConfigPatternMatcher
-  
- RegexPredicate - Class in com.hazelcast.query.impl.predicates
- 
Regex Predicate 
- RegexPredicate() - Constructor for class com.hazelcast.query.impl.predicates.RegexPredicate
-  
- RegexPredicate(String, String) - Constructor for class com.hazelcast.query.impl.predicates.RegexPredicate
-  
- RegionCache - Interface in com.hazelcast.hibernate
- 
This interface defines an internal cached region implementation as well as a mechanism
 to unmap the cache to an underlying Map data-structure 
- RegionFactoryBeanDefinitionParser - Class in com.hazelcast.spring.hibernate
- 
Parser for RegionFactory. 
- RegionFactoryBeanDefinitionParser() - Constructor for class com.hazelcast.spring.hibernate.RegionFactoryBeanDefinitionParser
-  
- REGIONS - Static variable in class com.hazelcast.jclouds.JCloudsProperties
- 
Property used to define regions for node filtering 
- register() - Method in class com.hazelcast.client.connection.nio.AbstractClientSelectionHandler
-  
- register(String, ClientProxyFactory) - Method in class com.hazelcast.client.spi.ProxyManager
-  
- register(String, Class<? extends ClientProxy>) - Method in class com.hazelcast.client.spi.ProxyManager
-  
- register(S, String, ProbeLevel, LongProbeFunction<S>) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
-  
- register(S, String, ProbeLevel, DoubleProbeFunction<S>) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
-  
- register(MetricsRegistry) - Static method in class com.hazelcast.internal.metrics.metricsets.ClassLoadingMetricSet
- 
Registers all the metrics in this metric pack. 
- register(MetricsRegistry) - Static method in class com.hazelcast.internal.metrics.metricsets.GarbageCollectionMetricSet
- 
Registers all the metrics in this metrics pack. 
- register(MetricsRegistry) - Static method in class com.hazelcast.internal.metrics.metricsets.OperatingSystemMetricsSet
- 
Registers all the metrics in this metrics pack. 
- register(MetricsRegistry) - Static method in class com.hazelcast.internal.metrics.metricsets.RuntimeMetricSet
- 
Registers all the metrics in this metrics pack. 
- register(MetricsRegistry) - Static method in class com.hazelcast.internal.metrics.metricsets.ThreadMetricSet
- 
Registers all the metrics in this metric pack. 
- register(S, String, ProbeLevel, LongProbeFunction<S>) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
- 
Registers a probe. 
- register(S, String, ProbeLevel, DoubleProbeFunction<S>) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
- 
Registers a probe
 If a probe for the given name exists, it will be overwritten. 
- register(Class, Serializer) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- register(HazelcastMBean) - Method in class com.hazelcast.jmx.HazelcastMBean
-  
- register(String, MapInterceptor) - Method in class com.hazelcast.map.impl.InterceptorRegistry
- 
- register(Selector, int, Object) - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-  
- register(Selector, int, Object) - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-  
- register(String, int, int, ExecutorType) - Method in interface com.hazelcast.spi.ExecutionService
-  
- register(String, int, int, ExecutorType) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-  
- register(Invocation) - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
- 
Registers an invocation. 
- REGISTER_MEMBERSHIP_LISTENER - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-  
- registerCache(LocalRegionCache) - Method in class com.hazelcast.hibernate.local.CleanupService
-  
- registerCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- registerCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- registerCacheObject(Object, String, String, boolean) - Static method in class com.hazelcast.cache.impl.MXBeanUtil
- 
Registers the provided CacheMXBeanorCacheStatisticsMXBeanimplementations if not registered yet.
 
- registerClassDefinition(ClassDefinition, Map<Integer, ClassDefinition>, boolean) - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1
-  
- registerClassDefinition(ClassDefinition) - Method in interface com.hazelcast.internal.serialization.PortableContext
-  
- registerClassDefinitions(Collection<ClassDefinition>, boolean) - Method in class com.hazelcast.internal.serialization.impl.SerializationServiceV1
-  
- registerClient(HazelcastInstance) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
-  
- registerConnection(Address, Connection) - Method in interface com.hazelcast.nio.ConnectionManager
-  
- registerConnection(Address, Connection) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- registerConstant(Class, Serializer) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- registerConstant(Class, SerializerAdapter) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- registerEndpoint(ClientEndpoint) - Method in interface com.hazelcast.client.ClientEndpointManager
- 
Registers an endpoint with this ClientEndpointManager. 
- registerEndpoint(ClientEndpoint) - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-  
- registerEngineExtension(String, ScriptEngineFactory) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
-  
- registerEngineMimeType(String, ScriptEngineFactory) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
-  
- registerEngineName(String, ScriptEngineFactory) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
-  
- registerExpiredAwaitOp(AwaitOperation) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- registerGlobal(Serializer) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- registerGlobal(Serializer, boolean) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- registerJobSupervisorCancellation(String, String, Address) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-  
- registerListener(String, CacheEventListener, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- registerListener(String, CacheEventListener, EventFilter, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- registerListener(String, CacheEventListener, boolean) - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- registerListener(String, CacheEventListener, EventFilter, boolean) - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- registerListener(ListenerMessageCodec, EventHandler) - Method in interface com.hazelcast.client.spi.ClientListenerService
-  
- registerListener(ListenerMessageCodec, EventHandler) - Method in class com.hazelcast.client.spi.ClientProxy
-  
- registerListener(ListenerMessageCodec, EventHandler) - Method in class com.hazelcast.client.spi.impl.listener.ClientNonSmartListenerService
-  
- registerListener(ListenerMessageCodec, EventHandler) - Method in class com.hazelcast.client.spi.impl.listener.ClientSmartListenerService
-  
- registerListener(Object) - Method in class com.hazelcast.instance.DefaultNodeExtension
-  
- registerListener(Object) - Method in interface com.hazelcast.instance.NodeExtension
- 
Registers given register if it's a known type. 
- registerListener(String, String, Object) - Method in interface com.hazelcast.spi.EventService
- 
Registers a listener on all cluster nodes. 
- registerListener(String, String, EventFilter, Object) - Method in interface com.hazelcast.spi.EventService
- 
Registers a listener on all cluster nodes with an event filter. 
- registerListener(String, String, Object) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-  
- registerListener(String, String, EventFilter, Object) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-  
- registerListenerInternal(String, CacheEventListener, EventFilter, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- registerListeners(CacheConfig<K, V>, ICache<K, V>) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- registerLocalListener(String, String, Object) - Method in interface com.hazelcast.spi.EventService
- 
Registers a local only listener. 
- registerLocalListener(String, String, EventFilter, Object) - Method in interface com.hazelcast.spi.EventService
- 
Registers a local only listener with an event filter. 
- registerLocalListener(String, String, Object) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-  
- registerLocalListener(String, String, EventFilter, Object) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-  
- registerLockStoreConstructor(String, ConstructorFunction<ObjectNamespace, LockStoreInfo>) - Method in interface com.hazelcast.concurrent.lock.LockService
-  
- registerLockStoreConstructor(String, ConstructorFunction<ObjectNamespace, LockStoreInfo>) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-  
- registerMapCombineTask(MapCombineTask<KeyIn, ValueIn, KeyOut, ValueOut, Chunk>) - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-  
- RegisterMembershipListenerRequest - Class in com.hazelcast.cluster.client
-  
- RegisterMembershipListenerRequest() - Constructor for class com.hazelcast.cluster.client.RegisterMembershipListenerRequest
-  
- RegisterMembershipListenerRequest(boolean) - Constructor for class com.hazelcast.cluster.client.RegisterMembershipListenerRequest
-  
- registerReducerEventInterests(int, Set<Address>) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-  
- registerReducerTask(ReducerTask<Key, Chunk>) - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-  
- registerServer(HazelcastInstance) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
-  
- registerSignalKey(ConditionKey) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- registerTrackableJob(TrackableJobFuture<V>) - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-  
- Registration - Class in com.hazelcast.spi.impl.eventservice.impl
-  
- Registration() - Constructor for class com.hazelcast.spi.impl.eventservice.impl.Registration
-  
- Registration(String, String, String, EventFilter, Address, Object, boolean) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.Registration
-  
- registrationExecutor - Variable in class com.hazelcast.client.spi.impl.listener.ClientListenerServiceImpl
-  
- registrationId - Variable in class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
-  
- RegistrationOperation - Class in com.hazelcast.spi.impl.eventservice.impl.operations
-  
- RegistrationOperation() - Constructor for class com.hazelcast.spi.impl.eventservice.impl.operations.RegistrationOperation
-  
- RegistrationOperation(Registration) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.operations.RegistrationOperation
-  
- REJECTED_EXECUTION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- rejectExecution() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-  
- release() - Method in class com.hazelcast.client.proxy.ClientSemaphoreProxy
-  
- release(int) - Method in class com.hazelcast.client.proxy.ClientSemaphoreProxy
-  
- release(int, String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-  
- release() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-  
- release(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-  
- release() - Method in interface com.hazelcast.core.ISemaphore
- 
Releases a permit, increasing the number of available permits by
 one. 
- release(int) - Method in interface com.hazelcast.core.ISemaphore
- 
Releases the given number of permits, increasing the number of
 available permits by that amount. 
- release(int) - Method in class com.hazelcast.jmx.SemaphoreMBean
-  
- RELEASE_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-  
- RELEASE_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-  
- ReleaseBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
-  
- ReleaseBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReleaseBackupOperation
-  
- ReleaseBackupOperation(String, int, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReleaseBackupOperation
-  
- ReleaseOperation - Class in com.hazelcast.concurrent.semaphore.operations
-  
- ReleaseOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
-  
- ReleaseOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
-  
- releaseReadLock() - Method in class com.hazelcast.query.impl.BaseIndexStore
-  
- ReleaseRequest - Class in com.hazelcast.concurrent.semaphore.client
-  
- ReleaseRequest() - Constructor for class com.hazelcast.concurrent.semaphore.client.ReleaseRequest
-  
- ReleaseRequest(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.client.ReleaseRequest
-  
- RELIABLE_TOPIC_MESSAGE - Static variable in class com.hazelcast.topic.impl.TopicDataSerializerHook
-  
- ReliableMessageListener<E> - Interface in com.hazelcast.topic
- 
- ReliableMessageListenerAdapter<E> - Class in com.hazelcast.topic.impl.reliable
-  
- ReliableMessageListenerAdapter(MessageListener<E>) - Constructor for class com.hazelcast.topic.impl.reliable.ReliableMessageListenerAdapter
-  
- ReliableTopicConfig - Class in com.hazelcast.config
- 
Configuration for a reliable  ITopic. 
- ReliableTopicConfig(String) - Constructor for class com.hazelcast.config.ReliableTopicConfig
- 
Creates a new ReliableTopicConfig with default settings. 
- ReliableTopicMessage - Class in com.hazelcast.topic.impl.reliable
- 
The Object that is going to be stored in the Ringbuffer. 
- ReliableTopicMessage() - Constructor for class com.hazelcast.topic.impl.reliable.ReliableTopicMessage
-  
- ReliableTopicMessage(Data, Address) - Constructor for class com.hazelcast.topic.impl.reliable.ReliableTopicMessage
-  
- ReliableTopicProxy<E> - Class in com.hazelcast.topic.impl.reliable
- 
The serverside  ITopic implementation for reliable topics. 
- ReliableTopicProxy(String, NodeEngine, ReliableTopicService, ReliableTopicConfig) - Constructor for class com.hazelcast.topic.impl.reliable.ReliableTopicProxy
-  
- ReliableTopicService - Class in com.hazelcast.topic.impl.reliable
-  
- ReliableTopicService(NodeEngine) - Constructor for class com.hazelcast.topic.impl.reliable.ReliableTopicService
-  
- reloadManagers() - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
- 
This method is the only one that is visible and not part of the ScriptEngineManager class. 
- reloadOwnedPartitions() - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- REMAINING_CAPACITY - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-  
- REMAINING_CAPACITY - Static variable in class com.hazelcast.collection.impl.queue.QueuePortableHook
-  
- REMAINING_CAPACITY - Static variable in class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
-  
- remainingCapacity() - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-  
- remainingCapacity() - Method in class com.hazelcast.client.proxy.ClientRingbufferProxy
-  
- remainingCapacity() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-  
- remainingCapacity() - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
-  
- remainingCapacity() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
- 
Returns the remaining capacity of the ringbuffer. 
- RemainingCapacityOperation - Class in com.hazelcast.collection.impl.queue.operations
- 
Returns the remaining capacity of the queue based on config max-size 
- RemainingCapacityOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.RemainingCapacityOperation
-  
- RemainingCapacityOperation(String) - Constructor for class com.hazelcast.collection.impl.queue.operations.RemainingCapacityOperation
-  
- RemainingCapacityRequest - Class in com.hazelcast.collection.impl.queue.client
- 
Request for remaining capacity of Queue. 
- RemainingCapacityRequest() - Constructor for class com.hazelcast.collection.impl.queue.client.RemainingCapacityRequest
-  
- RemainingCapacityRequest(String) - Constructor for class com.hazelcast.collection.impl.queue.client.RemainingCapacityRequest
-  
- RemainingCapacityRequest - Class in com.hazelcast.ringbuffer.impl.client
-  
- RemainingCapacityRequest() - Constructor for class com.hazelcast.ringbuffer.impl.client.RemainingCapacityRequest
-  
- RemainingCapacityRequest(String) - Constructor for class com.hazelcast.ringbuffer.impl.client.RemainingCapacityRequest
-  
- remainingQueueCapacity - Variable in class com.hazelcast.internal.management.dto.ManagedExecutorDTO
-  
- REMOTE_MAP_REDUCE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- RemoteEventProcessor - Class in com.hazelcast.spi.impl.eventservice.impl
-  
- RemoteEventProcessor(EventServiceImpl, Packet) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.RemoteEventProcessor
-  
- RemoteInvocationResponseHandler - Class in com.hazelcast.spi.impl.operationservice.impl
- 
- RemoteInvocationResponseHandler(InternalOperationService) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.RemoteInvocationResponseHandler
-  
- RemoteMapReduceException - Exception in com.hazelcast.mapreduce
- 
This exception class is used to show stack traces of multiple failed
 remote operations at once. 
- RemoteMapReduceException(String, List<Exception>) - Constructor for exception com.hazelcast.mapreduce.RemoteMapReduceException
-  
- remoteOperationCount - Variable in class com.hazelcast.internal.management.dto.OperationServiceDTO
-  
- remoteService - Variable in class com.hazelcast.map.impl.MapService
-  
- RemoteService - Interface in com.hazelcast.spi
- 
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
 distributed objects. 
- REMOVALS - Static variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- removals - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- remove(Data, String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- remove(Data, String, int, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- remove(Data, Object, String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- remove(Data, Object, String, int, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- remove() - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-  
- REMOVE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- remove() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-  
- REMOVE - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- remove(K) - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- remove(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- remove(Data, String, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Removes the mapping for a key from this cache if it is present. 
- remove(Data, Object, String, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Atomically removes the mapping for a key only if currently mapped to the
 given value. 
- remove(K) - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache
-  
- remove(K) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- remove(K) - Method in interface com.hazelcast.cache.impl.nearcache.NearCache
- 
Removes the value associated with the given key.
 
- remove(K) - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheRecordStore
- 
Removes the value associated with the given key.
 
- remove(Object) - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap
-  
- remove(Object, Object) - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap
-  
- remove(K) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- remove(K, V) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- remove(K) - Method in class com.hazelcast.client.map.impl.nearcache.ClientHeapNearCache
-  
- remove(Object) - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
-  
- remove(int) - Method in class com.hazelcast.client.proxy.ClientListProxy
-  
- remove(Object) - Method in class com.hazelcast.client.proxy.ClientListProxy
-  
- remove(Object) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- remove(Object, Object) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- remove(Object, Object) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-  
- remove(Object) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-  
- remove(Object) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-  
- remove() - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-  
- remove(Object) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-  
- remove(Object) - Method in class com.hazelcast.client.proxy.ClientSetProxy
-  
- remove(E) - Method in class com.hazelcast.client.proxy.txn.ClientTxnListProxy
-  
- remove(Object) - Method in class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-  
- remove(Object, Object) - Method in class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-  
- remove(Object, Object) - Method in class com.hazelcast.client.proxy.txn.ClientTxnMultiMapProxy
-  
- remove(Object) - Method in class com.hazelcast.client.proxy.txn.ClientTxnMultiMapProxy
-  
- remove(E) - Method in class com.hazelcast.client.proxy.txn.ClientTxnSetProxy
-  
- remove(E) - Method in class com.hazelcast.client.txn.proxy.ClientTxnListProxy
-  
- remove(Object) - Method in class com.hazelcast.client.txn.proxy.ClientTxnMapProxy
-  
- remove(Object, Object) - Method in class com.hazelcast.client.txn.proxy.ClientTxnMapProxy
-  
- remove(Object, Object) - Method in class com.hazelcast.client.txn.proxy.ClientTxnMultiMapProxy
-  
- remove(Object) - Method in class com.hazelcast.client.txn.proxy.ClientTxnMultiMapProxy
-  
- remove(E) - Method in class com.hazelcast.client.txn.proxy.ClientTxnSetProxy
-  
- remove(Object) - Method in class com.hazelcast.cluster.impl.MemberSelectingCollection
-  
- remove(Object) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-  
- remove(Data) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- remove(int) - Method in class com.hazelcast.collection.impl.list.ListContainer
-  
- remove(int) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
-  
- remove(Data) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
- 
iterates all items, checks equality with data
 This method does not trigger store load. 
- REMOVE - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-  
- remove() - Method in class com.hazelcast.collection.impl.queue.QueueIterator
-  
- REMOVE - Static variable in class com.hazelcast.collection.impl.queue.QueuePortableHook
-  
- remove(Object) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
-  
- remove() - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
-  
- remove(E) - Method in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
-  
- remove(Object) - Method in interface com.hazelcast.core.BaseMap
- 
Removes the mapping for a key from this map if it is present. 
- remove(Object, Object) - Method in interface com.hazelcast.core.BaseMap
- 
Removes the entry for a key only if currently mapped to a given value. 
- remove(Object, Object) - Method in interface com.hazelcast.core.BaseMultiMap
- 
Removes the given key value pair from the multimap. 
- remove(Object) - Method in interface com.hazelcast.core.BaseMultiMap
- 
Removes all the entries associated with the given key. 
- remove(Object) - Method in interface com.hazelcast.core.IMap
- 
Removes the mapping for a key from this map if it is present. 
- remove(Object, Object) - Method in interface com.hazelcast.core.IMap
- 
Removes the entry for a key only if currently mapped to a given value. 
- remove(Object, Object) - Method in interface com.hazelcast.core.MultiMap
- 
Removes the given key value pair from the multimap. 
- remove(Object) - Method in interface com.hazelcast.core.MultiMap
- 
Removes all the entries with the given key. 
- remove(E) - Method in interface com.hazelcast.core.TransactionalList
- 
Remove item from the transactional list 
- remove(Object) - Method in interface com.hazelcast.core.TransactionalMap
- 
- remove(Object, Object) - Method in interface com.hazelcast.core.TransactionalMap
- 
- remove(Object, Object) - Method in interface com.hazelcast.core.TransactionalMultiMap
- 
Removes the given key value pair from the multimap. 
- remove(Object) - Method in interface com.hazelcast.core.TransactionalMultiMap
- 
Removes all the entries associated with the given key. 
- remove(E) - Method in interface com.hazelcast.core.TransactionalSet
- 
Remove item from transactional set. 
- remove(Object) - Method in interface com.hazelcast.hibernate.access.AccessDelegate
- 
Called after an item has become stale (before the transaction completes). 
- remove(Object) - Method in class com.hazelcast.hibernate.access.NonStrictReadWriteAccessDelegate
-  
- remove(Object) - Method in class com.hazelcast.hibernate.access.ReadWriteAccessDelegate
- 
Called after an item has become stale (before the transaction completes). 
- remove(Object) - Method in class com.hazelcast.hibernate.distributed.IMapRegionCache
-  
- remove(Object) - Method in class com.hazelcast.hibernate.local.LocalRegionCache
-  
- remove(Object) - Method in class com.hazelcast.hibernate.region.CollectionRegionAccessStrategyAdapter
-  
- remove(Object) - Method in class com.hazelcast.hibernate.region.EntityRegionAccessStrategyAdapter
-  
- remove(Object) - Method in class com.hazelcast.hibernate.region.NaturalIdRegionAccessStrategyAdapter
-  
- remove(Object) - Method in interface com.hazelcast.hibernate.RegionCache
-  
- REMOVE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-  
- REMOVE - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- remove(K, long) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
-  
- remove(Data, long) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-  
- remove(Data, long) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
-  
- remove(Data) - Method in class com.hazelcast.map.impl.nearcache.NearCacheImpl
-  
- remove(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- remove(Object, Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- remove(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- remove(Data, Object) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- remove(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- remove(Data, Object) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- remove(Object, Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-  
- remove(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-  
- remove(Data, boolean) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-  
- REMOVE - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- REMOVE - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-  
- remove(Object, Object) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-  
- remove(Object) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-  
- remove(boolean) - Method in class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-  
- remove(Object, Object) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
-  
- remove(Object) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
-  
- REMOVE - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-  
- remove(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-  
- remove(K, ReplicatedRecord<K, V>) - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
-  
- remove(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- remove(Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-  
- remove(Object) - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
-  
- remove(Object) - Method in interface com.hazelcast.transaction.impl.Transaction
-  
- remove(Object) - Method in class com.hazelcast.transaction.impl.TransactionImpl
-  
- remove(Object) - Method in class com.hazelcast.transaction.impl.TransactionLog
-  
- remove(Object) - Method in class com.hazelcast.transaction.impl.xa.XATransaction
-  
- remove(int, int) - Method in class com.hazelcast.util.collection.BiInt2ObjectMap
- 
Remove a value from the map and return the value. 
- remove(Object) - Method in class com.hazelcast.util.collection.InflatableSet
-  
- remove(Object) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
-  
- remove(int) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
-  
- remove(Object) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
- remove(int) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
- 
- remove(Object) - Method in class com.hazelcast.util.collection.IntHashSet
- remove(int) - Method in class com.hazelcast.util.collection.IntHashSet
- 
An int specialised version of {this#remove(Object)}. 
- remove() - Method in class com.hazelcast.util.collection.IntIterator
-  
- remove(Object) - Method in class com.hazelcast.util.collection.Long2LongHashMap
- remove(long) - Method in class com.hazelcast.util.collection.Long2LongHashMap
-  
- remove(Object) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
-  
- remove(long) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
-  
- remove(Object) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
- remove(long) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
- 
- remove(Object) - Method in class com.hazelcast.util.collection.LongHashSet
- remove(long) - Method in class com.hazelcast.util.collection.LongHashSet
- 
An long specialised version of {this#remove(Object)}. 
- remove() - Method in class com.hazelcast.util.collection.LongIterator
-  
- remove(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
- 
Removes the key (and its corresponding value) from this map. 
- remove(Object, Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
- remove(T) - Method in class com.hazelcast.util.ItemCounter
-  
- remove() - Method in class com.hazelcast.util.UnmodifiableIterator
-  
- REMOVE_ALL - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- REMOVE_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- REMOVE_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-  
- REMOVE_ALL_BACKUP - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- REMOVE_ALL_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- REMOVE_ALL_FACTORY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- REMOVE_ALL_LISTENERS - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-  
- REMOVE_BACKUP - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- REMOVE_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-  
- REMOVE_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-  
- REMOVE_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- REMOVE_CACHE_PARTITION_LOST_LISTENER - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- REMOVE_ENTRY_LISTENER - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- REMOVE_ENTRY_LISTENER - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- REMOVE_ENTRY_LISTENER - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-  
- REMOVE_IF_SAME - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- REMOVE_INDEX - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- REMOVE_INDEX_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- REMOVE_INTERCEPTOR - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- REMOVE_INVALIDATION_LISTENER - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- REMOVE_LISTENER - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-  
- REMOVE_LISTENER - Static variable in class com.hazelcast.collection.impl.queue.QueuePortableHook
-  
- REMOVE_LISTENER - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-  
- REMOVE_LISTENER - Static variable in class com.hazelcast.topic.impl.TopicPortableHook
-  
- REMOVE_MAP_PARTITION_LOST_LISTENER - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- REMOVE_PARTITION_LOST_LISTENER - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-  
- REMOVE_TIME_TAKEN_NANOS - Static variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- removeAddress(Address) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- removeAll(Set<Data>, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- removeAll(Set<? extends K>) - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- removeAll() - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- removeAll(Set<Data>, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
records of keys will be deleted one by one and will publish a REMOVE event
 for each key. 
- removeAll(Set<? extends K>) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- removeAll() - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- removeAll(Collection<?>) - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
-  
- removeAll(Collection<?>) - Method in class com.hazelcast.client.proxy.ClientListProxy
-  
- removeAll(Collection<?>) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-  
- removeAll(Collection<?>) - Method in class com.hazelcast.client.proxy.ClientSetProxy
-  
- removeAll(Collection<?>) - Method in class com.hazelcast.cluster.impl.MemberSelectingCollection
-  
- removeAll(Collection<?>) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-  
- removeAll(Collection<?>) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
-  
- removeAll() - Method in interface com.hazelcast.hibernate.access.AccessDelegate
- 
Called to evict data from the entire region 
- removeAll() - Method in class com.hazelcast.hibernate.access.NonStrictReadWriteAccessDelegate
-  
- removeAll() - Method in class com.hazelcast.hibernate.access.ReadOnlyAccessDelegate
-  
- removeAll() - Method in class com.hazelcast.hibernate.access.ReadWriteAccessDelegate
- 
This is an asynchronous cache access strategy. 
- removeAll() - Method in class com.hazelcast.hibernate.region.CollectionRegionAccessStrategyAdapter
-  
- removeAll() - Method in class com.hazelcast.hibernate.region.EntityRegionAccessStrategyAdapter
-  
- removeAll() - Method in class com.hazelcast.hibernate.region.NaturalIdRegionAccessStrategyAdapter
-  
- removeAll(Collection) - Method in class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
- 
Directly removes keys from map store as in write-through mode. 
- removeAll(Collection) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
- 
Removes keys from map store. 
- removeAll(Collection<?>) - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
-  
- removeAll(Collection<?>) - Method in class com.hazelcast.util.collection.IntHashSet
- removeAll(Collection<?>) - Method in class com.hazelcast.util.collection.LongHashSet
- RemoveAllBackupOperation - Class in com.hazelcast.multimap.impl.operations
-  
- RemoveAllBackupOperation() - Constructor for class com.hazelcast.multimap.impl.operations.RemoveAllBackupOperation
-  
- RemoveAllBackupOperation(String, Data) - Constructor for class com.hazelcast.multimap.impl.operations.RemoveAllBackupOperation
-  
- removeAllInternal(Data) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-  
- RemoveAllListeners - Class in com.hazelcast.client.impl.client
- 
When a connection does not respond to heart-beat we switch the listeners to another endpoint
 If somehow connection starts to respond heart-beat we need to signal the endpoint to remove the listeners
 An internal request should not be used for user calls. 
- RemoveAllListeners() - Constructor for class com.hazelcast.client.impl.client.RemoveAllListeners
-  
- RemoveAllListenersMessageTask - Class in com.hazelcast.client.impl.protocol.task
-  
- RemoveAllListenersMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
-  
- RemoveAllOperation - Class in com.hazelcast.multimap.impl.operations
-  
- RemoveAllOperation() - Constructor for class com.hazelcast.multimap.impl.operations.RemoveAllOperation
-  
- RemoveAllOperation(String, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.RemoveAllOperation
-  
- RemoveAllRequest - Class in com.hazelcast.multimap.impl.client
-  
- RemoveAllRequest() - Constructor for class com.hazelcast.multimap.impl.client.RemoveAllRequest
-  
- RemoveAllRequest(String, Data, long) - Constructor for class com.hazelcast.multimap.impl.client.RemoveAllRequest
-  
- removeAsync(K) - Method in interface com.hazelcast.cache.ICache
- 
Asynchronously removes the mapping for a key from this cache if it is present. 
- removeAsync(K, V) - Method in interface com.hazelcast.cache.ICache
- 
Asynchronously removes the mapping for the given key if and only if the
 currently mapped value equals to the value of oldValue. 
- removeAsync(K) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- removeAsync(K) - Method in interface com.hazelcast.core.IMap
- 
Asynchronously removes the given key. 
- removeAsync(K) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- removeAsyncInternal(Data) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- removeAsyncInternal(Data) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- removeAsyncInternal(Data) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- removeAttribute(String) - Method in class com.hazelcast.client.impl.MemberImpl
-  
- removeAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-  
- removeAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-  
- removeAttribute(String) - Method in interface com.hazelcast.core.Member
- 
Removes a key-value pair attribute for this member if given key was
 previously assigned as an attribute.
 If key wasn't assigned to a value this method does nothing.
 
- removeAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-  
- removeAttribute(String) - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- removeAwait(Data, String, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- removeBackup(long) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- removeBackup(long) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- removeBackup(K, long) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
-  
- removeBackup(Data, long) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-  
- removeBackup(Data, long) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
-  
- removeBackup(Data) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- removeBackup(Data) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
- 
- RemoveBackupOperation - Class in com.hazelcast.collection.impl.queue.operations
- 
Remove backup of the Queue item. 
- RemoveBackupOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.RemoveBackupOperation
-  
- RemoveBackupOperation(String, long) - Constructor for class com.hazelcast.collection.impl.queue.operations.RemoveBackupOperation
-  
- RemoveBackupOperation - Class in com.hazelcast.map.impl.operation
-  
- RemoveBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.RemoveBackupOperation
-  
- RemoveBackupOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.RemoveBackupOperation
-  
- RemoveBackupOperation(String, Data, boolean) - Constructor for class com.hazelcast.map.impl.operation.RemoveBackupOperation
-  
- RemoveBackupOperation(String, Data, boolean, boolean) - Constructor for class com.hazelcast.map.impl.operation.RemoveBackupOperation
-  
- RemoveBackupOperation - Class in com.hazelcast.multimap.impl.operations
-  
- RemoveBackupOperation() - Constructor for class com.hazelcast.multimap.impl.operations.RemoveBackupOperation
-  
- RemoveBackupOperation(String, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.RemoveBackupOperation
-  
- removeCache(String, boolean) - Method in interface com.hazelcast.cache.HazelcastCacheManager
- 
Removes associated cache with the given cache name. 
- removeCache(String, boolean) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-  
- removeCacheConfigFromLocal(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
- 
Removes the local copy of the cache configuration if one exists. 
- removeCacheConfigFromLocal(String) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-  
- removeCacheConfigFromLocal(String) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
-  
- removeCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- removeCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in interface com.hazelcast.config.CacheConfiguration
- 
Remove a configuration for a CacheEntryListener.
 
- removeClientListener(String) - Method in class com.hazelcast.client.impl.ClientServiceProxy
-  
- removeClientListener(String) - Method in interface com.hazelcast.core.ClientService
- 
Removes a ClientListener. 
- removeConnection(TcpIpConnection) - Method in class com.hazelcast.nio.tcp.spinning.SpinningInputThread
-  
- removeConnection(TcpIpConnection) - Method in class com.hazelcast.nio.tcp.spinning.SpinningOutputThread
-  
- removeConnectionEventListener(ConnectionEventListener) - Method in class com.hazelcast.jca.ManagedConnectionImpl
-  
- removeContainers(int) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-  
- removeContainers(int) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-  
- removeDestroyAction(String) - Method in interface com.hazelcast.client.ClientEndpoint
-  
- removeDestroyAction(String) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- removeDistributedObjectListener(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- removeDistributedObjectListener(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- removeDistributedObjectListener(String) - Method in class com.hazelcast.client.spi.ProxyManager
-  
- removeDistributedObjectListener(String) - Method in interface com.hazelcast.core.HazelcastInstance
- 
Removes the specified Distributed Object listener. 
- removeDistributedObjectListener(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- removeDistributedObjectListener(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- removeDistributedObjectListener(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- RemoveDistributedObjectListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task
-  
- RemoveDistributedObjectListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.RemoveDistributedObjectListenerMessageTask
-  
- RemoveDistributedObjectListenerRequest - Class in com.hazelcast.client.impl.client
- 
Client request to remove a distributed object listener from a remote node. 
- RemoveDistributedObjectListenerRequest() - Constructor for class com.hazelcast.client.impl.client.RemoveDistributedObjectListenerRequest
-  
- removeEndpoint(ClientEndpoint) - Method in interface com.hazelcast.client.ClientEndpointManager
- 
Removes an endpoint from this ClientEndpointManager. 
- removeEndpoint(ClientEndpoint, boolean) - Method in interface com.hazelcast.client.ClientEndpointManager
- 
Removes an endpoint and optionally closes it immediately. 
- removeEndpoint(ClientEndpoint) - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-  
- removeEndpoint(ClientEndpoint, boolean) - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-  
- removeEndpoint(Address) - Method in interface com.hazelcast.nio.IOService
-  
- removeEndpoint(Address) - Method in class com.hazelcast.nio.NodeIOService
-  
- removeEndpoints(String) - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-  
- removeEntryIndex(Data, Object) - Method in interface com.hazelcast.query.impl.Index
-  
- removeEntryIndex(Data, Object) - Method in class com.hazelcast.query.impl.Indexes
-  
- removeEntryIndex(Data, Object) - Method in class com.hazelcast.query.impl.IndexImpl
-  
- removeEntryListener(String) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- removeEntryListener(String) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-  
- removeEntryListener(String) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-  
- removeEntryListener(String) - Method in interface com.hazelcast.core.IMap
- 
Removes the specified entry listener. 
- removeEntryListener(String) - Method in interface com.hazelcast.core.MultiMap
- 
Removes the specified entry listener. 
- removeEntryListener(String) - Method in interface com.hazelcast.core.ReplicatedMap
- 
Removes the specified entry listener. 
- removeEntryListener(String) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- removeEntryListener(String) - Method in interface com.hazelcast.map.QueryCache
-  
- removeEntryListener(String) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-  
- removeEntryListener(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-  
- RemoveEntryListenerRequest - Class in com.hazelcast.multimap.impl.client
-  
- RemoveEntryListenerRequest() - Constructor for class com.hazelcast.multimap.impl.client.RemoveEntryListenerRequest
-  
- RemoveEntryListenerRequest(String) - Constructor for class com.hazelcast.multimap.impl.client.RemoveEntryListenerRequest
-  
- removeEventHandler(long) - Method in class com.hazelcast.client.spi.impl.listener.ClientListenerServiceImpl
-  
- removeEventListener(String, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
-  
- removeEventListener(String, String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapEventPublishingService
-  
- removeFirstOccurrence(E) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
- 
Removes the first occurrence of the specified element in this queue
 when searching it by starting from the head of this queue. 
- removeIfSameInternal(Data, Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-  
- RemoveIfSameOperation - Class in com.hazelcast.map.impl.operation
-  
- RemoveIfSameOperation() - Constructor for class com.hazelcast.map.impl.operation.RemoveIfSameOperation
-  
- RemoveIfSameOperation(String, Data, Data) - Constructor for class com.hazelcast.map.impl.operation.RemoveIfSameOperation
-  
- removeIndex(Object, Data) - Method in class com.hazelcast.query.impl.BaseIndexStore
-  
- removeIndex(Object, Data) - Method in interface com.hazelcast.query.impl.IndexStore
-  
- removeInterceptor(String) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- removeInterceptor(String) - Method in interface com.hazelcast.core.IMap
- 
Removes the given interceptor for this map so it will not intercept operations anymore. 
- removeInterceptor(String, String) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
-  
- removeInterceptor(String) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- RemoveInterceptorOperation - Class in com.hazelcast.map.impl.operation
-  
- RemoveInterceptorOperation() - Constructor for class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
-  
- RemoveInterceptorOperation(String, String) - Constructor for class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
-  
- RemoveInterceptorOperationFactory - Class in com.hazelcast.map.impl.operation
-  
- RemoveInterceptorOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.RemoveInterceptorOperationFactory
-  
- RemoveInterceptorOperationFactory(String, String) - Constructor for class com.hazelcast.map.impl.operation.RemoveInterceptorOperationFactory
-  
- removeInternal(Data) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- removeInternal(Data, Data) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- removeInternal(Data) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- removeInternal(Data, Data) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- removeInternal(Data) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- removeInternal(Data, Data) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- removeInternal(Data) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-  
- removeInternal(Data, Data) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-  
- removeInternal(Data) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-  
- removeInternal(Data, Data) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-  
- removeItemListener(String) - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
-  
- removeItemListener(String) - Method in class com.hazelcast.client.proxy.ClientListProxy
-  
- removeItemListener(String) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-  
- removeItemListener(String) - Method in class com.hazelcast.client.proxy.ClientSetProxy
-  
- removeItemListener(String) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-  
- removeItemListener(String, String) - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- removeItemListener(String) - Method in interface com.hazelcast.core.ICollection
- 
Removes the specified item listener. 
- removeLifecycleListener(String) - Method in class com.hazelcast.client.impl.LifecycleServiceImpl
-  
- removeLifecycleListener(String) - Method in interface com.hazelcast.core.LifecycleService
- 
Removes a lifecycle listener 
- removeLifecycleListener(String) - Method in class com.hazelcast.instance.LifecycleServiceImpl
-  
- removeLifecycleListener(String) - Method in class com.hazelcast.instance.TerminatedLifecycleService
-  
- removeListener(String, String) - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- RemoveListenerRequest - Class in com.hazelcast.collection.impl.queue.client
- 
Remove listener request belong to the Queue item. 
- RemoveListenerRequest() - Constructor for class com.hazelcast.collection.impl.queue.client.RemoveListenerRequest
-  
- RemoveListenerRequest(String) - Constructor for class com.hazelcast.collection.impl.queue.client.RemoveListenerRequest
-  
- removeLogListener(LogListener) - Method in interface com.hazelcast.logging.LoggingService
-  
- removeLogListener(LogListener) - Method in class com.hazelcast.logging.LoggingServiceImpl
-  
- removeMapContainer(MapContainer) - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- removeMember(Member) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
-  
- removeMember(Member) - Method in interface com.hazelcast.partition.membergroup.MemberGroup
-  
- removeMember(Member) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
-  
- removeMembershipListener(String) - Method in class com.hazelcast.client.proxy.ClientClusterProxy
-  
- removeMembershipListener(String) - Method in interface com.hazelcast.client.spi.ClientClusterService
-  
- removeMembershipListener(String) - Method in class com.hazelcast.client.spi.impl.ClientClusterServiceImpl
-  
- removeMembershipListener(String) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- removeMembershipListener(String) - Method in interface com.hazelcast.core.Cluster
- 
Removes the specified MembershipListener. 
- removeMessageListener(String) - Method in class com.hazelcast.client.proxy.ClientReliableTopicProxy
-  
- removeMessageListener(String) - Method in class com.hazelcast.client.proxy.ClientTopicProxy
-  
- removeMessageListener(String) - Method in interface com.hazelcast.core.ITopic
- 
Stops receiving messages for the given message listener. 
- removeMessageListener(String) - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicProxy
-  
- removeMessageListener(String) - Method in class com.hazelcast.topic.impl.TopicProxy
-  
- removeMessageListener(String, String) - Method in class com.hazelcast.topic.impl.TopicService
-  
- removeMessageListenerInternal(String) - Method in class com.hazelcast.topic.impl.TopicProxySupport
-  
- RemoveMessageListenerRequest - Class in com.hazelcast.topic.impl.client
-  
- RemoveMessageListenerRequest() - Constructor for class com.hazelcast.topic.impl.client.RemoveMessageListenerRequest
-  
- RemoveMessageListenerRequest(String) - Constructor for class com.hazelcast.topic.impl.client.RemoveMessageListenerRequest
-  
- removeMigrationListener(String) - Method in class com.hazelcast.client.proxy.PartitionServiceProxy
-  
- removeMigrationListener(String) - Method in interface com.hazelcast.core.PartitionService
- 
Removes a MigrationListener. 
- removeMigrationListener(String) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- removeMigrationListener(String) - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- removeMigrationListener(String) - Method in class com.hazelcast.partition.PartitionServiceProxy
-  
- removeModifierSuffix(String) - Static method in class com.hazelcast.query.impl.getters.SuffixModifierUtils
- 
Remove modifier suffix from given fullName. 
- removeMulticastListener(MulticastListener) - Method in class com.hazelcast.cluster.impl.MulticastService
-  
- removeNearCacheInvalidationListener() - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- removeNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-  
- removeNotificationListener(NotificationListener) - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-  
- RemoveOperation - Class in com.hazelcast.collection.impl.queue.operations
- 
Remove operation for the Queue. 
- RemoveOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.RemoveOperation
-  
- RemoveOperation(String, Data) - Constructor for class com.hazelcast.collection.impl.queue.operations.RemoveOperation
-  
- RemoveOperation - Class in com.hazelcast.map.impl.operation
-  
- RemoveOperation() - Constructor for class com.hazelcast.map.impl.operation.RemoveOperation
-  
- RemoveOperation(String, Data, boolean) - Constructor for class com.hazelcast.map.impl.operation.RemoveOperation
-  
- RemoveOperation - Class in com.hazelcast.multimap.impl.operations
-  
- RemoveOperation() - Constructor for class com.hazelcast.multimap.impl.operations.RemoveOperation
-  
- RemoveOperation(String, Data, long, Data) - Constructor for class com.hazelcast.multimap.impl.operations.RemoveOperation
-  
- RemoveOperation - Class in com.hazelcast.replicatedmap.impl.operation
- 
Removes the key from replicated map. 
- RemoveOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.RemoveOperation
-  
- RemoveOperation(String, Data) - Constructor for class com.hazelcast.replicatedmap.impl.operation.RemoveOperation
-  
- removeOwnershipMapping(String) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- removePartitioningStrategyFromCache(String) - Static method in class com.hazelcast.map.impl.PartitioningStrategyFactory
- 
Remove the cached PartitioningStrategyfrom the internal cache, if it exists.
 
- removePartitionLostListener(String) - Method in interface com.hazelcast.cache.ICache
- 
Removes the specified cache partition lost listener. 
- removePartitionLostListener(String) - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- removePartitionLostListener(String) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- removePartitionLostListener(String) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- removePartitionLostListener(String) - Method in class com.hazelcast.client.proxy.PartitionServiceProxy
-  
- removePartitionLostListener(String) - Method in interface com.hazelcast.core.IMap
- 
Removes the specified map partition lost listener. 
- removePartitionLostListener(String) - Method in interface com.hazelcast.core.PartitionService
- 
Removes a PartitionLostListener. 
- removePartitionLostListener(String, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
-  
- removePartitionLostListener(String) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- removePartitionLostListener(String) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- removePartitionLostListener(String) - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- removePartitionLostListener(String) - Method in class com.hazelcast.partition.PartitionServiceProxy
-  
- RemovePartitionLostListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task
-  
- RemovePartitionLostListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
-  
- RemovePartitionLostListenerRequest - Class in com.hazelcast.partition.client
-  
- RemovePartitionLostListenerRequest() - Constructor for class com.hazelcast.partition.client.RemovePartitionLostListenerRequest
-  
- removeProperty(String) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
-  
- removeProxy(ClientProxy) - Method in class com.hazelcast.client.spi.ClientContext
-  
- removeProxy(String, String) - Method in class com.hazelcast.client.spi.ProxyManager
-  
- removeProxyListener(String) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-  
- removeProxyListener(String) - Method in interface com.hazelcast.spi.ProxyService
-  
- removeRecord(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- removeRecord(Data) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Removes the record for a key. 
- removeRecord(K) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- removeRecord(K) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.BaseHeapNearCacheRecordStore
-  
- removeRecord(Data, Record, long) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- removeRecord(R) - Method in interface com.hazelcast.map.impl.recordstore.Storage
-  
- removeRecords(Collection<Record>) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- removeRegistration(String, String) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceSegment
-  
- RemoveRequest - Class in com.hazelcast.collection.impl.queue.client
- 
Remove Request for the Queue. 
- RemoveRequest() - Constructor for class com.hazelcast.collection.impl.queue.client.RemoveRequest
-  
- RemoveRequest(String, Data) - Constructor for class com.hazelcast.collection.impl.queue.client.RemoveRequest
-  
- RemoveRequest - Class in com.hazelcast.multimap.impl.client
-  
- RemoveRequest() - Constructor for class com.hazelcast.multimap.impl.client.RemoveRequest
-  
- RemoveRequest(String, Data, Data, long) - Constructor for class com.hazelcast.multimap.impl.client.RemoveRequest
-  
- removeSignalKey(ConditionKey) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- removeSize(int, RecordStore) - Method in interface com.hazelcast.map.impl.eviction.Evictor
- 
Remove supplied number of elements from record-store. 
- removeSize(int, RecordStore) - Method in class com.hazelcast.map.impl.eviction.EvictorImpl
-  
- removeThreadId() - Static method in class com.hazelcast.util.ThreadUtil
- 
Remove the thread id 
- removeTimeTakenNanos - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
-  
- removeTransactionContext(String) - Method in interface com.hazelcast.client.ClientEndpoint
-  
- removeTransactionContext(String) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- removeTransactions(SerializableXID) - Method in class com.hazelcast.transaction.impl.xa.XAService
-  
- removeValue(String) - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- removeWhiteSpace(byte[]) - Static method in class com.hazelcast.util.Base64
- 
remove WhiteSpace from MIME containing encoded Base64
 data. 
- render(ProbeRenderer) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
-  
- render(ProbeRenderer) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
- 
Renders the content of the MetricsRegistry. 
- renderDouble(String, double) - Method in class com.hazelcast.internal.metrics.renderers.CommaSeparatedKeyValueProbeRenderer
-  
- renderDouble(String, double) - Method in class com.hazelcast.internal.metrics.renderers.HumanFriendlyProbeRenderer
-  
- renderDouble(String, double) - Method in interface com.hazelcast.internal.metrics.renderers.ProbeRenderer
-  
- renderException(String, Exception) - Method in class com.hazelcast.internal.metrics.renderers.CommaSeparatedKeyValueProbeRenderer
-  
- renderException(String, Exception) - Method in class com.hazelcast.internal.metrics.renderers.HumanFriendlyProbeRenderer
-  
- renderException(String, Exception) - Method in interface com.hazelcast.internal.metrics.renderers.ProbeRenderer
-  
- renderLong(String, long) - Method in class com.hazelcast.internal.metrics.renderers.CommaSeparatedKeyValueProbeRenderer
-  
- renderLong(String, long) - Method in class com.hazelcast.internal.metrics.renderers.HumanFriendlyProbeRenderer
-  
- renderLong(String, long) - Method in interface com.hazelcast.internal.metrics.renderers.ProbeRenderer
-  
- renderNoValue(String) - Method in class com.hazelcast.internal.metrics.renderers.CommaSeparatedKeyValueProbeRenderer
-  
- renderNoValue(String) - Method in class com.hazelcast.internal.metrics.renderers.HumanFriendlyProbeRenderer
-  
- renderNoValue(String) - Method in interface com.hazelcast.internal.metrics.renderers.ProbeRenderer
-  
- renew() - Method in class com.hazelcast.client.spi.impl.CallIdSequence.CallIdSequenceFailFast
-  
- renew() - Method in class com.hazelcast.client.spi.impl.CallIdSequence
- 
Creates the call id without applying any backpressure 
- replace(K, V, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
- 
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 ExpiryPolicy.
 
- replace(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
- 
Atomically replaces the assigned value of the given key by the specified value
 using a custom ExpiryPolicy.
 
- replace(Data, Object, ExpiryPolicy, String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- replace(Data, Object, Object, ExpiryPolicy, String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- REPLACE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- REPLACE - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- replace(K, V, V) - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- replace(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
-  
- replace(Data, Object, ExpiryPolicy, String, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Atomically replaces the entry for a key only if currently mapped to some
 value. 
- replace(Data, Object, Object, ExpiryPolicy, String, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Atomically replaces the entry for a key only if currently mapped to a
 given value. 
- replace(K, V, V) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- replace(K, V) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-  
- replace(K, V, V) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- replace(K, V) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- replace(K, V) - Method in class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-  
- replace(K, V, V) - Method in class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-  
- replace(K, V) - Method in class com.hazelcast.client.txn.proxy.ClientTxnMapProxy
-  
- replace(K, V, V) - Method in class com.hazelcast.client.txn.proxy.ClientTxnMapProxy
-  
- replace(K, V) - Method in interface com.hazelcast.core.BaseMap
- 
Replaces the entry for a key only if it is currently mapped to some value. 
- replace(K, V, V) - Method in interface com.hazelcast.core.BaseMap
- 
Replaces the entry for a key only if currently mapped to a given value. 
- replace(K, V, V) - Method in interface com.hazelcast.core.IMap
- 
Replaces the entry for a key only if currently mapped to a given value. 
- replace(K, V) - Method in interface com.hazelcast.core.IMap
- 
Replaces the entry for a key only if it is currently mapped to some value. 
- replace(K, V) - Method in interface com.hazelcast.core.TransactionalMap
- 
- replace(K, V, V) - Method in interface com.hazelcast.core.TransactionalMap
- 
- replace(String, String, Object) - Method in interface com.hazelcast.internal.ascii.TextCommandService
-  
- replace(String, String, Object) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- REPLACE - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- replace(K, V, V) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- replace(K, V) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- replace(Data, Object) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- replace(Data, Object, Object) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- replace(Data, Object) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- replace(Data, Object, Object) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
- 
- replace(Object, Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-  
- replace(Object, Object, Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-  
- replace(K, V, V) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
- replace(K, V) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
- REPLACE_IF_SAME - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- replaceAsync(K, V) - Method in interface com.hazelcast.cache.ICache
- 
Asynchronously replaces the assigned value of the given key by the specified value. 
- replaceAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
- 
Asynchronously replaces the assigned value of the given key by the specified value
 using a custom ExpiryPolicy.
 
- replaceAsync(K, V, V) - Method in interface com.hazelcast.cache.ICache
- 
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. 
- replaceAsync(K, V, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
- 
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.
 
- replaceIfSameInternal(Data, Data, Data) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- replaceIfSameInternal(Data, Data, Data) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- replaceIfSameInternal(Data, Object, Data) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-  
- ReplaceIfSameOperation - Class in com.hazelcast.map.impl.operation
-  
- ReplaceIfSameOperation() - Constructor for class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
-  
- ReplaceIfSameOperation(String, Data, Data, Data) - Constructor for class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
-  
- replaceInternal(Data, Data) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- replaceInternal(Data, Data) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- replaceInternal(Data, Data, Data) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- replaceInternal(Data, Data) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- replaceInternal(Data, Data) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-  
- ReplaceOperation - Class in com.hazelcast.map.impl.operation
-  
- ReplaceOperation(String, Data, Data) - Constructor for class com.hazelcast.map.impl.operation.ReplaceOperation
-  
- ReplaceOperation() - Constructor for class com.hazelcast.map.impl.operation.ReplaceOperation
-  
- REPLICA_SYNC_RETRY_DELAY - Static variable in interface com.hazelcast.partition.InternalPartitionService
-  
- replicaBackupLog(List<TransactionLogRecord>, String, String, long, long) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-  
- replicaChanged(PartitionReplicaChangeEvent) - Method in interface com.hazelcast.partition.impl.PartitionListener
-  
- ReplicaErrorLogger - Class in com.hazelcast.partition
-  
- replicaIndex - Variable in class com.hazelcast.spi.InvocationBuilder
-  
- ReplicaSyncInfo - Class in com.hazelcast.partition.impl
-  
- ReplicaSyncRequest - Class in com.hazelcast.partition.impl
-  
- ReplicaSyncRequest() - Constructor for class com.hazelcast.partition.impl.ReplicaSyncRequest
-  
- ReplicaSyncRequest(int, int) - Constructor for class com.hazelcast.partition.impl.ReplicaSyncRequest
-  
- ReplicaSyncResponse - Class in com.hazelcast.partition.impl
-  
- ReplicaSyncResponse() - Constructor for class com.hazelcast.partition.impl.ReplicaSyncResponse
-  
- ReplicaSyncResponse(List<Operation>, long[]) - Constructor for class com.hazelcast.partition.impl.ReplicaSyncResponse
-  
- ReplicaSyncRetryResponse - Class in com.hazelcast.partition.impl
-  
- ReplicaSyncRetryResponse() - Constructor for class com.hazelcast.partition.impl.ReplicaSyncRetryResponse
-  
- REPLICATE_ALLOWED_DURING_PASSIVE_STATE_TX_BACKUP_LOG - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
-  
- REPLICATE_TX_BACKUP_LOG - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
-  
- ReplicateAllowedDuringPassiveStateTxBackupLogOperation - Class in com.hazelcast.transaction.impl.operations
-  
- ReplicateAllowedDuringPassiveStateTxBackupLogOperation() - Constructor for class com.hazelcast.transaction.impl.operations.ReplicateAllowedDuringPassiveStateTxBackupLogOperation
-  
- ReplicateAllowedDuringPassiveStateTxBackupLogOperation(List<TransactionLogRecord>, String, String, long, long) - Constructor for class com.hazelcast.transaction.impl.operations.ReplicateAllowedDuringPassiveStateTxBackupLogOperation
-  
- replicateClearOperation() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperation
-  
- REPLICATED_MAP_CANT_BE_CREATED - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- REPLICATED_MAP_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- REPLICATED_MAP_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- REPLICATED_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- REPLICATED_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- ReplicatedEntryEventFilter - Class in com.hazelcast.replicatedmap.impl.record
- 
Basic filter implementation for selecting interesting events on the server 
- ReplicatedEntryEventFilter(Data) - Constructor for class com.hazelcast.replicatedmap.impl.record.ReplicatedEntryEventFilter
-  
- ReplicatedMap<K,V> - Interface in com.hazelcast.core
- 
A ReplicatedMap is a map-like data structure with weak consistency
 and values locally stored on every node of the cluster. 
- ReplicatedMapAddEntryListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
-  
- ReplicatedMapAddEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerMessageTask
-  
- ReplicatedMapAddEntryListenerToKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
-  
- ReplicatedMapAddEntryListenerToKeyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyMessageTask
-  
- ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
-  
- ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask
-  
- ReplicatedMapAddEntryListenerWithPredicateMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
-  
- ReplicatedMapAddEntryListenerWithPredicateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddEntryListenerWithPredicateMessageTask
-  
- ReplicatedMapAddNearCacheListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
-  
- ReplicatedMapAddNearCacheListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapAddNearCacheListenerMessageTask
-  
- ReplicatedMapCantBeCreatedOnLiteMemberException - Exception in com.hazelcast.replicatedmap
- 
- ReplicatedMapCantBeCreatedOnLiteMemberException(Address) - Constructor for exception com.hazelcast.replicatedmap.ReplicatedMapCantBeCreatedOnLiteMemberException
-  
- ReplicatedMapCantBeCreatedOnLiteMemberException(String) - Constructor for exception com.hazelcast.replicatedmap.ReplicatedMapCantBeCreatedOnLiteMemberException
-  
- ReplicatedMapClearMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
-  
- ReplicatedMapClearMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
-  
- ReplicatedMapConfig - Class in com.hazelcast.config
- 
- ReplicatedMapConfig() - Constructor for class com.hazelcast.config.ReplicatedMapConfig
-  
- ReplicatedMapConfig(String) - Constructor for class com.hazelcast.config.ReplicatedMapConfig
- 
Creates a ReplicatedMapConfig with the given name. 
- ReplicatedMapConfig(ReplicatedMapConfig) - Constructor for class com.hazelcast.config.ReplicatedMapConfig
-  
- replicatedMapConfig - Variable in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-  
- ReplicatedMapContainsKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
-  
- ReplicatedMapContainsKeyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsKeyMessageTask
-  
- ReplicatedMapContainsValueMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
-  
- ReplicatedMapContainsValueMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsValueMessageTask
-  
- ReplicatedMapDataSerializerHook - Class in com.hazelcast.replicatedmap.impl.operation
- 
This class contains all the ID hooks for IdentifiedDataSerializable classes used inside the replicated map. 
- ReplicatedMapDataSerializerHook() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-  
- ReplicatedMapEntries - Class in com.hazelcast.replicatedmap.impl.client
- 
An implementation of a portable implementing entry set for client results on entrySet requests 
- ReplicatedMapEntries() - Constructor for class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
-  
- ReplicatedMapEntries(List<Map.Entry<Data, Data>>) - Constructor for class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
-  
- ReplicatedMapEntrySetMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
-  
- ReplicatedMapEntrySetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapEntrySetMessageTask
-  
- ReplicatedMapEntryView<K,V> - Class in com.hazelcast.replicatedmap.impl.record
-  
- ReplicatedMapEntryView(K, V) - Constructor for class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- ReplicatedMapEntryView() - Constructor for class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- ReplicatedMapEventPublishingService - Class in com.hazelcast.replicatedmap.impl
- 
Dispatches published events on replicated map to corresponding listeners. 
- ReplicatedMapEventPublishingService(ReplicatedMapService) - Constructor for class com.hazelcast.replicatedmap.impl.ReplicatedMapEventPublishingService
-  
- ReplicatedMapEvictionProcessor - Class in com.hazelcast.replicatedmap.impl
- 
Actual eviction processor implementation to remove values to evict values from the replicated map 
- ReplicatedMapEvictionProcessor(ReplicatedRecordStore, NodeEngine, int) - Constructor for class com.hazelcast.replicatedmap.impl.ReplicatedMapEvictionProcessor
-  
- ReplicatedMapGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
-  
- ReplicatedMapGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
-  
- ReplicatedMapIsEmptyMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
-  
- ReplicatedMapIsEmptyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapIsEmptyMessageTask
-  
- ReplicatedMapKeys - Class in com.hazelcast.replicatedmap.impl.client
- 
Class to implement a replicated map keySet result 
- ReplicatedMapKeys() - Constructor for class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeys
-  
- ReplicatedMapKeys(List<Data>) - Constructor for class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeys
-  
- ReplicatedMapKeySetMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
-  
- ReplicatedMapKeySetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapKeySetMessageTask
-  
- ReplicatedMapMBean - Class in com.hazelcast.jmx
- 
- ReplicatedMapMBean(ReplicatedMapProxy, ManagementService) - Constructor for class com.hazelcast.jmx.ReplicatedMapMBean
-  
- ReplicatedMapMergePolicy - Interface in com.hazelcast.replicatedmap.merge
- 
A policy for merging replicated maps after a split-brain was detected and the different network partitions need
 to be merged. 
- ReplicatedMapPermission - Class in com.hazelcast.security.permission
-  
- ReplicatedMapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ReplicatedMapPermission
-  
- ReplicatedMapPortableEntryEvent - Class in com.hazelcast.replicatedmap.impl.client
- 
Class to redirect entry listener events on the members to the listening client 
- ReplicatedMapPortableHook - Class in com.hazelcast.replicatedmap.impl.client
- 
This class registers all Portable serializers that are needed for communication between nodes and clients 
- ReplicatedMapPortableHook() - Constructor for class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-  
- ReplicatedMapProxy<K,V> - Class in com.hazelcast.replicatedmap.impl
- 
- ReplicatedMapPutAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
-  
- ReplicatedMapPutAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
-  
- ReplicatedMapPutMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
-  
- ReplicatedMapPutMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutMessageTask
-  
- ReplicatedMapRemoveEntryListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
-  
- ReplicatedMapRemoveEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
-  
- ReplicatedMapRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
-  
- ReplicatedMapRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveMessageTask
-  
- replicatedMapService - Variable in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-  
- ReplicatedMapService - Class in com.hazelcast.replicatedmap.impl
- 
This is the main service implementation to handle proxy creation, event publishing, migration, anti-entropy and
 manages the backing  PartitionContainers that actually hold the data 
- ReplicatedMapService(NodeEngine) - Constructor for class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- ReplicatedMapSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
-  
- ReplicatedMapSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapSizeMessageTask
-  
- ReplicatedMapSplitBrainHandlerService - Class in com.hazelcast.replicatedmap.impl
- 
- ReplicatedMapSplitBrainHandlerService(ReplicatedMapService, MergePolicyProvider) - Constructor for class com.hazelcast.replicatedmap.impl.ReplicatedMapSplitBrainHandlerService
-  
- ReplicatedMapValueCollection - Class in com.hazelcast.replicatedmap.impl.client
- 
Class implementing a replicated map value collection result 
- ReplicatedMapValueCollection(Collection<Data>) - Constructor for class com.hazelcast.replicatedmap.impl.client.ReplicatedMapValueCollection
-  
- ReplicatedMapValuesMessageTask - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
-  
- ReplicatedMapValuesMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapValuesMessageTask
-  
- ReplicatedQueryEventFilter - Class in com.hazelcast.replicatedmap.impl.record
- 
This class is used to transfer a predicate as an remote operation and filter values matching the predicate 
- ReplicatedQueryEventFilter(Data, Predicate) - Constructor for class com.hazelcast.replicatedmap.impl.record.ReplicatedQueryEventFilter
-  
- ReplicatedRecord<K,V> - Class in com.hazelcast.replicatedmap.impl.record
- 
A ReplicatedRecord is the actual data holding entity. 
- ReplicatedRecord(K, V, long) - Constructor for class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-  
- ReplicatedRecordStore - Interface in com.hazelcast.replicatedmap.impl.record
- 
This interface describes a common record store for replicated maps and their actual records 
- ReplicateTxBackupLogOperation - Class in com.hazelcast.transaction.impl.operations
- 
Replicates the transactionlog to a remote system. 
- ReplicateTxBackupLogOperation() - Constructor for class com.hazelcast.transaction.impl.operations.ReplicateTxBackupLogOperation
-  
- ReplicateTxBackupLogOperation(List<TransactionLogRecord>, String, String, long, long) - Constructor for class com.hazelcast.transaction.impl.operations.ReplicateTxBackupLogOperation
-  
- ReplicateUpdateOperation - Class in com.hazelcast.replicatedmap.impl.operation
- 
Replicates the update happened on the partition owner to the other nodes. 
- ReplicateUpdateOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateOperation
-  
- ReplicateUpdateOperation(String, Data, Data, long, VersionResponsePair, boolean, Address) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateOperation
-  
- ReplicateUpdateToCallerOperation - Class in com.hazelcast.replicatedmap.impl.operation
- 
This operation will update the local record store with the update received from local/remote partition owner. 
- ReplicateUpdateToCallerOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateToCallerOperation
-  
- ReplicateUpdateToCallerOperation(String, long, Data, Data, VersionResponsePair, long, boolean) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateToCallerOperation
-  
- REPLICATION - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-  
- REPLICATION - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-  
- REPLICATION_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
-  
- ReplicationEventObject - Interface in com.hazelcast.wan
- 
Marker interface for WAN replication messages 
- ReplicationOperation - Class in com.hazelcast.replicatedmap.impl.operation
- 
Carries all the partition data for replicated map from old owner to the new owner. 
- ReplicationOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicationOperation
-  
- ReplicationOperation(SerializationService, PartitionContainer, int) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicationOperation
-  
- ReplicationOperation - Class in com.hazelcast.ringbuffer.impl.operations
-  
- ReplicationOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.ReplicationOperation
-  
- ReplicationOperation(Map<String, RingbufferContainer>, int, int) - Constructor for class com.hazelcast.ringbuffer.impl.operations.ReplicationOperation
-  
- replicationSupportingService - Variable in class com.hazelcast.map.impl.MapService
-  
- ReplicationSupportingService - Interface in com.hazelcast.spi
- 
An interface that can be implemented by SPI services to give them the ability to listen to
 Replication Events. 
- REQUEST_MEMBERID_ASSIGNMENT - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-  
- REQUEST_PARTITION_MAPPING - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-  
- REQUEST_PARTITION_PROCESSED - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-  
- REQUEST_PARTITION_REDUCING - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-  
- REQUEST_PARTITION_RESULT - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-  
- REQUEST_TYPE_CHANGE_CLUSTER_STATE - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
-  
- REQUEST_TYPE_CLUSTER_PROPERTIES - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
-  
- REQUEST_TYPE_CLUSTER_SHUTDOWN - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
-  
- REQUEST_TYPE_CLUSTER_STATE - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
-  
- REQUEST_TYPE_CONSOLE_COMMAND - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
-  
- REQUEST_TYPE_EVICT_LOCAL_MAP - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
-  
- REQUEST_TYPE_EXECUTE_SCRIPT - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
-  
- REQUEST_TYPE_FORCE_START_NODE - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
-  
- REQUEST_TYPE_GET_CLUSTER_STATE - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
-  
- REQUEST_TYPE_GET_THREAD_DUMP - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
-  
- REQUEST_TYPE_LOG_VERSION_MISMATCH - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
-  
- REQUEST_TYPE_LOGS - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
-  
- REQUEST_TYPE_MAP_CONFIG - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
-  
- REQUEST_TYPE_MAP_ENTRY - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
-  
- REQUEST_TYPE_MEMBER_CONFIG - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
-  
- REQUEST_TYPE_MEMBER_SHUTDOWN - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
-  
- REQUEST_TYPE_MEMBER_SYSTEM_PROPERTIES - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
-  
- REQUEST_TYPE_RUN_GC - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
-  
- REQUEST_TYPE_SYSTEM_WARNINGS - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
-  
- REQUEST_TYPE_WAN_PUBLISHER - Static variable in class com.hazelcast.internal.management.request.ConsoleRequestConstants
-  
- requestChunk() - Method in class com.hazelcast.mapreduce.impl.task.DefaultContext
-  
- RequestMapDataOperation - Class in com.hazelcast.replicatedmap.impl.operation
- 
- RequestMapDataOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.RequestMapDataOperation
-  
- RequestMapDataOperation(String) - Constructor for class com.hazelcast.replicatedmap.impl.operation.RequestMapDataOperation
-  
- RequestMemberIdAssignment - Class in com.hazelcast.mapreduce.impl.operation
- 
This operation is used to do some kind of partitionId based processing on non partition based implementations
 of  KeyValueSource (not implementing  PartitionIdAware)
 which can happen for custom data sources like distributed filesystems that are up to the end user on how to
 manage the distribution. 
- RequestMemberIdAssignment() - Constructor for class com.hazelcast.mapreduce.impl.operation.RequestMemberIdAssignment
-  
- RequestMemberIdAssignment(String, String) - Constructor for class com.hazelcast.mapreduce.impl.operation.RequestMemberIdAssignment
-  
- requestMigration(NonBlockingIOThread) - Method in interface com.hazelcast.nio.tcp.nonblocking.MigratableHandler
- 
Requests the MigratableHandler to move to the new NonBlockingIOThread. 
- requestMigration(NonBlockingIOThread) - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingSocketReader
- 
Migrates this handler to a new NonBlockingIOThread. 
- requestMigration(NonBlockingIOThread) - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingSocketWriter
-  
- RequestPartitionMapping - Class in com.hazelcast.mapreduce.impl.operation
- 
This operation requests a new partition to process by the requester on the job owning node 
- RequestPartitionMapping() - Constructor for class com.hazelcast.mapreduce.impl.operation.RequestPartitionMapping
-  
- RequestPartitionMapping(String, String) - Constructor for class com.hazelcast.mapreduce.impl.operation.RequestPartitionMapping
-  
- RequestPartitionProcessed - Class in com.hazelcast.mapreduce.impl.operation
- 
This operation tells the job owner to mark a partition as fully processed 
- RequestPartitionProcessed() - Constructor for class com.hazelcast.mapreduce.impl.operation.RequestPartitionProcessed
-  
- RequestPartitionProcessed(String, String, int, JobPartitionState.State) - Constructor for class com.hazelcast.mapreduce.impl.operation.RequestPartitionProcessed
-  
- RequestPartitionReducing - Class in com.hazelcast.mapreduce.impl.operation
- 
This operation tells the job owner to start reducing phase of the defined partition on the first
 occurrence of a full emitted chunk 
- RequestPartitionReducing() - Constructor for class com.hazelcast.mapreduce.impl.operation.RequestPartitionReducing
-  
- RequestPartitionReducing(String, String, int) - Constructor for class com.hazelcast.mapreduce.impl.operation.RequestPartitionReducing
-  
- RequestPartitionResult - Class in com.hazelcast.mapreduce.impl.operation
- 
This class is used to store the requested result of all kinds of processing operations.
 By default it holds a basic result state and maybe the partitionId it was operated otherwise
 it's value is defined as -1
 
- RequestPartitionResult() - Constructor for class com.hazelcast.mapreduce.impl.operation.RequestPartitionResult
-  
- RequestPartitionResult(RequestPartitionResult.ResultState, int) - Constructor for class com.hazelcast.mapreduce.impl.operation.RequestPartitionResult
-  
- RequestPartitionResult.ResultState - Enum in com.hazelcast.mapreduce.impl.operation
- 
This enum is used to define the basic state of an operations result 
- requiresPrepare() - Method in class com.hazelcast.transaction.impl.TransactionImpl
- 
Checks if this Transaction needs to be prepared. 
- RES_100 - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
-  
- RES_200 - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
-  
- RES_204 - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
-  
- RES_400 - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
-  
- RES_403 - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
-  
- RES_404 - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
-  
- RES_500 - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
-  
- RES_503 - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
-  
- reserveAdd(String, Data) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- reserveAddBackup(long, String) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- reserveRemove(long, Data, String) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- reserveRemoveBackup(long, String) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- reset() - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- reset() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- reset() - Method in class com.hazelcast.cluster.impl.AbstractJoiner
-  
- reset() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- reset() - Method in interface com.hazelcast.cluster.Joiner
-  
- reset() - Method in class com.hazelcast.collection.impl.collection.CollectionService
-  
- reset() - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- reset() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-  
- reset() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-  
- reset() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-  
- reset() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorService
-  
- reset() - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-  
- reset() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-  
- reset() - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-  
- reset() - Method in class com.hazelcast.instance.Node
- 
Resets the internal cluster-state of the Node to be able to make it ready to join a new cluster. 
- reset() - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- reset() - Method in class com.hazelcast.map.impl.MapManagedService
-  
- reset() - Method in class com.hazelcast.map.impl.MapService
-  
- reset() - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- reset() - Method in class com.hazelcast.map.impl.nearcache.BatchInvalidator
-  
- reset() - Method in interface com.hazelcast.map.impl.nearcache.NearCacheInvalidator
- 
Resets this invalidator back to its initial state. 
- reset() - Method in class com.hazelcast.map.impl.nearcache.NearCacheProvider
-  
- reset() - Method in class com.hazelcast.map.impl.nearcache.NearCacheSizeEstimator
-  
- reset() - Method in class com.hazelcast.map.impl.nearcache.NonStopInvalidator
-  
- reset() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
- 
Resets the record store to it's initial state. 
- reset() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
- 
Resets the record store to it's initial state. 
- reset() - Method in interface com.hazelcast.map.impl.SizeEstimator
-  
- reset() - Method in class com.hazelcast.mapreduce.Combiner
- 
This method is always called after a chunk of data is retrieved. 
- reset() - Method in class com.hazelcast.mapreduce.impl.ListKeyValueSource
-  
- reset() - Method in class com.hazelcast.mapreduce.impl.MapKeyValueSource
-  
- reset() - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-  
- reset() - Method in class com.hazelcast.mapreduce.impl.MultiMapKeyValueSource
-  
- reset() - Method in class com.hazelcast.mapreduce.impl.SetKeyValueSource
-  
- reset() - Method in class com.hazelcast.mapreduce.KeyValueSource
- 
This method resets all internal state to be a new instance. 
- reset() - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- reset() - Method in interface com.hazelcast.nio.BufferObjectDataInput
-  
- reset() - Method in class com.hazelcast.nio.Packet
-  
- reset() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionMonitor
-  
- reset() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- reset() - Method in class com.hazelcast.query.PagingPredicate
- 
resets for reuse 
- reset() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-  
- reset() - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
-  
- reset() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- reset() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- reset() - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-  
- reset() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- reset() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
-  
- reset() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- reset() - Method in class com.hazelcast.spi.impl.waitnotifyservice.impl.WaitNotifyServiceImpl
-  
- reset() - Method in interface com.hazelcast.spi.ManagedService
- 
reset this ManagedService back to initial state. 
- reset() - Method in class com.hazelcast.topic.impl.TopicService
-  
- reset() - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-  
- reset() - Method in class com.hazelcast.transaction.impl.xa.XAService
-  
- reset() - Method in class com.hazelcast.util.ItemCounter
- 
Reset state of the counter to 0. 
- resetAccessHit() - Method in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-  
- resetAccessHit() - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheRecord
- 
Resets the access hit count of this  Evictable to  0. 
- resetAccessHit() - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-  
- resetAccessHit() - Method in interface com.hazelcast.cache.impl.record.CacheRecord
- 
Resets the access hit count of this  Evictable to  0. 
- resetCacheEntryListenerCount() - Method in class com.hazelcast.cache.impl.CacheContext
-  
- resetEntryCount() - Method in class com.hazelcast.cache.impl.CacheContext
-  
- resetInvalidationListenerCount() - Method in class com.hazelcast.cache.impl.CacheContext
-  
- resizeThreshold() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
- 
Get the actual threshold which when reached the map resize. 
- resizeThreshold() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
- 
Get the actual threshold which when reached the map resize. 
- ResourceAdapterImpl - Class in com.hazelcast.jca
- 
This is the starting point of the whole resource adapter for hazelcast. 
- ResourceAdapterImpl() - Constructor for class com.hazelcast.jca.ResourceAdapterImpl
-  
- resources - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-  
- response - Variable in class com.hazelcast.client.spi.impl.ClientInvocationFuture
-  
- response - Variable in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
-  
- response - Variable in class com.hazelcast.collection.impl.queue.operations.QueueOperation
-  
- response - Variable in class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
-  
- response - Variable in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
-  
- response - Variable in class com.hazelcast.concurrent.lock.operations.BaseLockOperation
-  
- response - Variable in class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
-  
- response - Variable in class com.hazelcast.internal.ascii.rest.HttpCommand
-  
- response - Variable in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-  
- response - Variable in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
-  
- Response - Class in com.hazelcast.spi.impl.operationservice.impl.responses
- 
- Response() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.responses.Response
-  
- Response(long, boolean) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.responses.Response
-  
- RESPONSE_ALREADY_SENT - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- ResponseAlreadySentException - Exception in com.hazelcast.spi.exception
- 
A HazelcastException indicating that there is some kind of system error causing a response to be send
 multiple times for some operation. 
- ResponseAlreadySentException() - Constructor for exception com.hazelcast.spi.exception.ResponseAlreadySentException
-  
- ResponseAlreadySentException(String) - Constructor for exception com.hazelcast.spi.exception.ResponseAlreadySentException
-  
- ResponseHandler - Interface in com.hazelcast.spi
- 
Deprecated. 
- ResponseMessageConst - Class in com.hazelcast.client.impl.protocol
- 
Message type ids of responses in client protocol. 
- ResponseNotSentException - Exception in com.hazelcast.spi.exception
- 
A HazelcastException indicating that there is some kind of system error causing
 a response NOT to be sent for some operation. 
- ResponseNotSentException(String) - Constructor for exception com.hazelcast.spi.exception.ResponseNotSentException
-  
- ResponseQueueFactory - Class in com.hazelcast.util
- 
Factory for creating response queues. 
- responseQueueSize - Variable in class com.hazelcast.internal.management.dto.OperationServiceDTO
-  
- RestValue - Class in com.hazelcast.internal.ascii.rest
-  
- RestValue() - Constructor for class com.hazelcast.internal.ascii.rest.RestValue
-  
- RestValue(byte[], byte[]) - Constructor for class com.hazelcast.internal.ascii.rest.RestValue
-  
- result - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-  
- resultDeserialized - Variable in class com.hazelcast.spi.InvocationBuilder
-  
- ResultSet<K,V> - Class in com.hazelcast.replicatedmap.impl.record
-  
- ResultSet(List<Map.Entry<K, V>>, IterationType) - Constructor for class com.hazelcast.replicatedmap.impl.record.ResultSet
-  
- resume(String, String) - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
-  
- resume(String, String) - Method in interface com.hazelcast.wan.WanReplicationService
- 
Resumes wan replication to target group for the called node. 
- resumeMigration() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- resumeMigration() - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- retainAll(Collection<?>) - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
-  
- retainAll(Collection<?>) - Method in class com.hazelcast.client.proxy.ClientListProxy
-  
- retainAll(Collection<?>) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-  
- retainAll(Collection<?>) - Method in class com.hazelcast.client.proxy.ClientSetProxy
-  
- retainAll(Collection<?>) - Method in class com.hazelcast.cluster.impl.MemberSelectingCollection
-  
- retainAll(Collection<?>) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-  
- retainAll(Collection<?>) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
-  
- retainAll(Collection<?>) - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
-  
- retainAll(Collection<?>) - Method in class com.hazelcast.util.collection.IntHashSet
-  
- retainAll(Collection<?>) - Method in class com.hazelcast.util.collection.LongHashSet
-  
- rethrow(Throwable) - Static method in class com.hazelcast.util.ExceptionUtil
-  
- rethrow(Throwable, Class<T>) - Static method in class com.hazelcast.util.ExceptionUtil
-  
- RETHROW_EVERYTHING - Static variable in class com.hazelcast.util.FutureUtil
- 
Just rethrows all exceptions 
- RETHROW_EXECUTION_EXCEPTION - Static variable in class com.hazelcast.util.FutureUtil
- 
- RETHROW_TRANSACTION_EXCEPTION - Static variable in class com.hazelcast.util.FutureUtil
- 
Handler for transaction specific rethrown of exceptions. 
- rethrowAllowedTypeFirst(Throwable, Class<T>) - Static method in class com.hazelcast.util.ExceptionUtil
- 
This rethrow the exception providing an allowed Exception in first priority, even it is a Runtime exception 
- rethrowAllowInterrupted(Throwable) - Static method in class com.hazelcast.util.ExceptionUtil
-  
- retrieveInitialSequence() - Method in class com.hazelcast.topic.impl.reliable.ReliableMessageListenerAdapter
-  
- retrieveInitialSequence() - Method in interface com.hazelcast.topic.ReliableMessageListener
- 
Retrieves the initial sequence from which this ReliableMessageListener should start. 
- RETRY_COUNT - Static variable in class com.hazelcast.map.impl.LocalMapStatsProvider
-  
- RETRY_WAIT_TIME_IN_SECONDS - Static variable in class com.hazelcast.client.spi.impl.ClientInvocation
-  
- RETRYABLE_HAZELCAST - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- RETRYABLE_IO - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- RetryableException - Interface in com.hazelcast.spi.exception
- 
Marker interface for exceptions to indicate that an operation can be retried. 
- RetryableHazelcastException - Exception in com.hazelcast.spi.exception
- 
A 'marker' exception that indicates that an operation can be retried. 
- RetryableHazelcastException() - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
-  
- RetryableHazelcastException(String) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
-  
- RetryableHazelcastException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
-  
- RetryableHazelcastException(Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
-  
- RetryableIOException - Exception in com.hazelcast.spi.exception
- 
A  IOException indicating that there was a IO failure, but it can be retried. 
- RetryableIOException() - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
-  
- RetryableIOException(String) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
-  
- RetryableIOException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
-  
- RetryableIOException(Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
-  
- RetryableRequest - Interface in com.hazelcast.client.impl.client
-  
- RETURN - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
-  
- RETURN_END - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
-  
- returnInputBuffer(BufferObjectDataInput) - Method in interface com.hazelcast.internal.serialization.impl.bufferpool.BufferPool
- 
Returns a BufferObjectDataInput back to the pool. 
- returnInputBuffer(BufferObjectDataInput) - Method in class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolImpl
-  
- returnOutputBuffer(BufferObjectDataOutput) - Method in interface com.hazelcast.internal.serialization.impl.bufferpool.BufferPool
- 
Returns a BufferObjectDataOutput back to the pool. 
- returnOutputBuffer(BufferObjectDataOutput) - Method in class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolImpl
-  
- returnsResponse() - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-  
- returnsResponse() - Method in class com.hazelcast.client.impl.operations.ClientDisconnectionOperation
-  
- returnsResponse() - Method in class com.hazelcast.client.impl.operations.ClientReAuthOperation
-  
- returnsResponse() - Method in class com.hazelcast.client.impl.operations.PostJoinClientOperation
-  
- returnsResponse() - Method in class com.hazelcast.cluster.impl.operations.MemberInfoUpdateOperation
-  
- returnsResponse() - Method in class com.hazelcast.cluster.impl.operations.MergeClustersOperation
-  
- returnsResponse() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
-  
- returnsResponse() - Method in class com.hazelcast.collection.impl.queue.operations.QueueOperation
-  
- returnsResponse() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTransactionRollbackOperation
-  
- returnsResponse() - Method in class com.hazelcast.collection.impl.txnqueue.operations.QueueTransactionRollbackOperation
-  
- returnsResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
-  
- returnsResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
-  
- returnsResponse() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-  
- returnsResponse() - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
-  
- returnsResponse() - Method in class com.hazelcast.internal.management.operation.GetMapConfigOperation
-  
- returnsResponse() - Method in class com.hazelcast.internal.management.operation.ScriptExecutorOperation
-  
- returnsResponse() - Method in class com.hazelcast.internal.management.operation.ThreadDumpOperation
-  
- returnsResponse() - Method in class com.hazelcast.internal.management.operation.UpdateManagementCenterUrlOperation
-  
- returnsResponse() - Method in class com.hazelcast.internal.management.operation.UpdateMapConfigOperation
-  
- returnsResponse() - Method in class com.hazelcast.map.impl.operation.ClearExpiredOperation
-  
- returnsResponse() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-  
- returnsResponse() - Method in class com.hazelcast.map.impl.operation.NearCacheBatchInvalidationOperation
-  
- returnsResponse() - Method in class com.hazelcast.map.impl.operation.NearCacheSingleInvalidationOperation
-  
- returnsResponse() - Method in class com.hazelcast.map.impl.operation.PartitionCheckIfLoadedOperation
-  
- returnsResponse() - Method in class com.hazelcast.mapreduce.impl.operation.NotifyRemoteExceptionOperation
-  
- returnsResponse() - Method in class com.hazelcast.mapreduce.impl.operation.StartProcessingJobOperation
-  
- returnsResponse() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-  
- returnsResponse() - Method in class com.hazelcast.partition.impl.CheckReplicaVersion
-  
- returnsResponse() - Method in class com.hazelcast.partition.impl.IsReplicaVersionSync
-  
- returnsResponse() - Method in class com.hazelcast.partition.impl.MigrationRequestOperation
-  
- returnsResponse() - Method in class com.hazelcast.partition.impl.PartitionStateOperation
-  
- returnsResponse() - Method in class com.hazelcast.partition.impl.ReplicaSyncRequest
-  
- returnsResponse() - Method in class com.hazelcast.partition.impl.ReplicaSyncResponse
-  
- returnsResponse() - Method in class com.hazelcast.partition.impl.ReplicaSyncRetryResponse
-  
- returnsResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
-  
- returnsResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperation
-  
- returnsResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.ContainsKeyOperation
-  
- returnsResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.ContainsValueOperation
-  
- returnsResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.EntrySetOperation
-  
- returnsResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.GetOperation
-  
- returnsResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.IsEmptyOperation
-  
- returnsResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.KeySetOperation
-  
- returnsResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.SizeOperation
-  
- returnsResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.ValuesOperation
-  
- returnsResponse() - Method in class com.hazelcast.spi.AbstractOperation
-  
- returnsResponse() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.PostJoinRegistrationOperation
-  
- returnsResponse() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
-  
- returnsResponse() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.IsStillExecutingOperation
-  
- returnsResponse() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.TraceableIsStillExecutingOperation
-  
- returnsResponse() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.PostJoinProxyOperation
-  
- returnsResponse() - Method in class com.hazelcast.spi.Operation
-  
- returnsResponse() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionBackupOperation
-  
- returnsResponse() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionBackupOperation
-  
- returnsResponse() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
-  
- returnsResponse() - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionBackupOperation
-  
- returnValue - Variable in class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
-  
- returnWithDeadline(Collection<Future<V>>, long, TimeUnit) - Static method in class com.hazelcast.util.FutureUtil
-  
- returnWithDeadline(Collection<Future<V>>, long, TimeUnit, FutureUtil.ExceptionHandler) - Static method in class com.hazelcast.util.FutureUtil
-  
- returnWithDeadline(Collection<Future<V>>, long, TimeUnit, long, TimeUnit) - Static method in class com.hazelcast.util.FutureUtil
-  
- returnWithDeadline(Collection<Future<V>>, long, TimeUnit, long, TimeUnit, FutureUtil.ExceptionHandler) - Static method in class com.hazelcast.util.FutureUtil
-  
- Ringbuffer<E> - Interface in com.hazelcast.ringbuffer
- 
A Ringbuffer is a data-structure where the content is stored in a ring like structure. 
- RINGBUFFER_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- RINGBUFFER_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- RINGBUFFER_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- RINGBUFFER_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- RingbufferAddAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.ringbuffer
- 
Client Protocol Task for handling messages with type id:
 QueueMessageType.QUEUE_OFFER
 
- RingbufferAddAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddAllMessageTask
-  
- RingbufferAddMessageTask - Class in com.hazelcast.client.impl.protocol.task.ringbuffer
- 
Client Protocol Task for handling messages with type id:
 QueueMessageType.QUEUE_OFFER
 
- RingbufferAddMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferAddMessageTask
-  
- RingbufferCapacityMessageTask - Class in com.hazelcast.client.impl.protocol.task.ringbuffer
-  
- RingbufferCapacityMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferCapacityMessageTask
-  
- RingbufferConfig - Class in com.hazelcast.config
- 
- RingbufferConfig(String) - Constructor for class com.hazelcast.config.RingbufferConfig
- 
Creates a RingbufferConfig with the provided name. 
- RingbufferConfig(RingbufferConfig) - Constructor for class com.hazelcast.config.RingbufferConfig
- 
Clones a RingbufferConfig 
- RingbufferConfig(String, RingbufferConfig) - Constructor for class com.hazelcast.config.RingbufferConfig
- 
Creates a new RingbufferConfig by cloning an existing config and overriding the name. 
- RingbufferContainer - Class in com.hazelcast.ringbuffer.impl
- 
The RingbufferContainer is responsible for storing the actual content of a ringbuffer. 
- RingbufferContainer(String) - Constructor for class com.hazelcast.ringbuffer.impl.RingbufferContainer
-  
- RingbufferContainer(RingbufferConfig, SerializationService) - Constructor for class com.hazelcast.ringbuffer.impl.RingbufferContainer
-  
- RingbufferContainer(String, RingbufferConfig, SerializationService) - Constructor for class com.hazelcast.ringbuffer.impl.RingbufferContainer
-  
- RingbufferDataSerializerHook - Class in com.hazelcast.ringbuffer.impl
- 
- RingbufferDataSerializerHook() - Constructor for class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
-  
- RingbufferHeadSequenceMessageTask - Class in com.hazelcast.client.impl.protocol.task.ringbuffer
-  
- RingbufferHeadSequenceMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferHeadSequenceMessageTask
-  
- RingBufferPermission - Class in com.hazelcast.security.permission
-  
- RingBufferPermission(String, String...) - Constructor for class com.hazelcast.security.permission.RingBufferPermission
-  
- RingbufferPortableHook - Class in com.hazelcast.ringbuffer.impl.client
- 
Provides a Portable hook for the ringbuffer operations. 
- RingbufferPortableHook() - Constructor for class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
-  
- RingbufferProxy<E> - Class in com.hazelcast.ringbuffer.impl
- 
- RingbufferProxy(NodeEngine, RingbufferService, String, RingbufferConfig) - Constructor for class com.hazelcast.ringbuffer.impl.RingbufferProxy
-  
- RingbufferReadManyMessageTask - Class in com.hazelcast.client.impl.protocol.task.ringbuffer
- 
Client Protocol Task for handling messages with type id:
 QueueMessageType.QUEUE_OFFER
 
- RingbufferReadManyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadManyMessageTask
-  
- RingbufferReadOneMessageTask - Class in com.hazelcast.client.impl.protocol.task.ringbuffer
- 
Client Protocol Task for handling messages with type id:
 QueueMessageType.QUEUE_OFFER
 
- RingbufferReadOneMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferReadOneMessageTask
-  
- RingbufferRemainingCapacityMessageTask - Class in com.hazelcast.client.impl.protocol.task.ringbuffer
-  
- RingbufferRemainingCapacityMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferRemainingCapacityMessageTask
-  
- RingbufferRequest - Class in com.hazelcast.ringbuffer.impl.client
-  
- RingbufferRequest() - Constructor for class com.hazelcast.ringbuffer.impl.client.RingbufferRequest
-  
- RingbufferRequest(String) - Constructor for class com.hazelcast.ringbuffer.impl.client.RingbufferRequest
-  
- RingbufferService - Class in com.hazelcast.ringbuffer.impl
- 
- RingbufferService(NodeEngineImpl) - Constructor for class com.hazelcast.ringbuffer.impl.RingbufferService
-  
- RingbufferSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.ringbuffer
-  
- RingbufferSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferSizeMessageTask
-  
- RingbufferTailSequenceMessageTask - Class in com.hazelcast.client.impl.protocol.task.ringbuffer
-  
- RingbufferTailSequenceMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.ringbuffer.RingbufferTailSequenceMessageTask
-  
- RingbufferWaitNotifyKey - Class in com.hazelcast.ringbuffer.impl
- 
- RingbufferWaitNotifyKey(String, String) - Constructor for class com.hazelcast.ringbuffer.impl.RingbufferWaitNotifyKey
-  
- ROLE_NAME - Static variable in class com.hazelcast.jclouds.JCloudsProperties
- 
Property used to define IAM roles specific to AWS-EC2 
- rollback(Xid) - Method in class com.hazelcast.client.proxy.txn.xa.XAResourceProxy
-  
- rollback(Xid) - Method in class com.hazelcast.client.txn.proxy.xa.XAResourceProxy
-  
- rollback() - Method in class com.hazelcast.jca.HazelcastTransactionImpl
-  
- ROLLBACK - Static variable in class com.hazelcast.transaction.client.ClientTxnPortableHook
-  
- rollback() - Method in interface com.hazelcast.transaction.impl.Transaction
-  
- rollback() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-  
- rollback(NodeEngine) - Method in class com.hazelcast.transaction.impl.TransactionLog
-  
- rollback(Xid) - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
-  
- rollback() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
-  
- ROLLBACK_ALLOWED_DURING_PASSIVE_STATE_TX_BACKUP_LOG - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
-  
- ROLLBACK_TX_BACKUP_LOG - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
-  
- ROLLBACK_XA - Static variable in class com.hazelcast.transaction.client.ClientTxnPortableHook
-  
- rollbackAdd(long) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- rollbackAddBackup(long) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- RollbackAllowedDuringPassiveStateTxBackupLogOperation - Class in com.hazelcast.transaction.impl.operations
-  
- RollbackAllowedDuringPassiveStateTxBackupLogOperation() - Constructor for class com.hazelcast.transaction.impl.operations.RollbackAllowedDuringPassiveStateTxBackupLogOperation
-  
- RollbackAllowedDuringPassiveStateTxBackupLogOperation(String) - Constructor for class com.hazelcast.transaction.impl.operations.RollbackAllowedDuringPassiveStateTxBackupLogOperation
-  
- rollbackAsync(NodeEngine, ExecutionCallback) - Method in class com.hazelcast.transaction.impl.TransactionLog
-  
- rollbackAsync(ExecutionCallback) - Method in class com.hazelcast.transaction.impl.xa.XATransaction
-  
- rollbackBackupLog(String) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-  
- rollbackClusterState(String) - Method in class com.hazelcast.cluster.impl.ClusterStateManager
-  
- RollbackClusterStateOperation - Class in com.hazelcast.cluster.impl.operations
-  
- RollbackClusterStateOperation() - Constructor for class com.hazelcast.cluster.impl.operations.RollbackClusterStateOperation
-  
- RollbackClusterStateOperation(Address, String) - Constructor for class com.hazelcast.cluster.impl.operations.RollbackClusterStateOperation
-  
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.collection.impl.collection.CollectionService
-  
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-  
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-  
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-  
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-  
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-  
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.map.impl.MapService
-  
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-  
- rollbackMigration(PartitionMigrationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
-  
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.transaction.impl.xa.XAService
-  
- rollbackRemove(long) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- rollbackRemove(long) - Method in class com.hazelcast.collection.impl.list.ListContainer
-  
- rollbackRemoveBackup(long) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- rollbackTransaction() - Method in class com.hazelcast.client.proxy.txn.TransactionContextProxy
-  
- rollbackTransaction() - Method in class com.hazelcast.client.proxy.txn.xa.XATransactionContextProxy
-  
- rollbackTransaction() - Method in class com.hazelcast.client.txn.proxy.xa.XATransactionContextProxy
-  
- rollbackTransaction() - Method in class com.hazelcast.client.txn.TransactionContextProxy
-  
- rollbackTransaction(String) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- rollbackTransaction(String) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- rollbackTransaction(String) - Method in class com.hazelcast.collection.impl.collection.CollectionService
-  
- rollbackTransaction(String) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- rollbackTransaction(String) - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- rollbackTransaction(String) - Method in class com.hazelcast.map.impl.MapService
-  
- rollbackTransaction(String) - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- rollbackTransaction(String) - Method in interface com.hazelcast.spi.TransactionalService
-  
- rollbackTransaction() - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
-  
- rollbackTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
- 
Rollback of the current transaction. 
- RollbackTransactionRequest - Class in com.hazelcast.transaction.client
-  
- RollbackTransactionRequest() - Constructor for class com.hazelcast.transaction.client.RollbackTransactionRequest
-  
- RollbackTxBackupLogOperation - Class in com.hazelcast.transaction.impl.operations
-  
- RollbackTxBackupLogOperation() - Constructor for class com.hazelcast.transaction.impl.operations.RollbackTxBackupLogOperation
-  
- RollbackTxBackupLogOperation(String) - Constructor for class com.hazelcast.transaction.impl.operations.RollbackTxBackupLogOperation
-  
- RollbackXATransactionRequest - Class in com.hazelcast.transaction.client
-  
- RollbackXATransactionRequest() - Constructor for class com.hazelcast.transaction.client.RollbackXATransactionRequest
-  
- RollbackXATransactionRequest(String) - Constructor for class com.hazelcast.transaction.client.RollbackXATransactionRequest
-  
- RoundRobinLB - Class in com.hazelcast.client.util
- 
A  LoadBalancer implementation that relies on using round robin
 to a next member to send a request to. 
- RoundRobinLB() - Constructor for class com.hazelcast.client.util.RoundRobinLB
-  
- RoundRobinLB(int) - Constructor for class com.hazelcast.client.util.RoundRobinLB
-  
- RUBY - Static variable in class com.hazelcast.client.ClientTypes
- 
RUBY client protocol id 
- RuleBasedQueryOptimizer - Class in com.hazelcast.query.impl.predicates
- 
Rule based optimizer. 
- RuleBasedQueryOptimizer() - Constructor for class com.hazelcast.query.impl.predicates.RuleBasedQueryOptimizer
-  
- run() - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache.ExpirationTask
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheContainsKeyOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheDestroyOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheGetOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheKeyIteratorOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CachePutBackupOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperation
-  
- run() - Method in class com.hazelcast.cache.impl.operation.PostJoinCacheOperation
-  
- run() - Method in class com.hazelcast.client.connection.nio.ClientReadHandler
-  
- run() - Method in class com.hazelcast.client.connection.nio.ClientWriteHandler
-  
- run() - Method in class com.hazelcast.client.impl.ClientEngineImpl.ClientPacketProcessor
-  
- run() - Method in class com.hazelcast.client.impl.ClientHeartbeatMonitor
-  
- run() - Method in class com.hazelcast.client.impl.operations.ClientDisconnectionOperation
-  
- run() - Method in class com.hazelcast.client.impl.operations.ClientReAuthOperation
-  
- run() - Method in class com.hazelcast.client.impl.operations.GetConnectedClientsOperation
-  
- run() - Method in class com.hazelcast.client.impl.operations.PostJoinClientOperation
-  
- run() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-  
- run() - Method in class com.hazelcast.client.spi.impl.ClientInvocation
-  
- run() - Method in class com.hazelcast.cluster.impl.MulticastService
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.AuthenticationFailureOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.AuthorizationOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.BeforeJoinCheckFailureOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.ChangeClusterStateOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.ConfigMismatchOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.FinalizeJoinOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.GroupMismatchOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.HeartbeatOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.JoinCheckOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.JoinRequestOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.LockClusterStateOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.MasterClaimOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.MasterConfirmationOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.MasterDiscoveryOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.MemberAttributeChangedOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.MemberInfoUpdateOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.MemberRemoveOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.MergeClustersOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.PostJoinOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.RollbackClusterStateOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.SetMasterOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.ShutdownNodeOperation
-  
- run() - Method in class com.hazelcast.cluster.impl.operations.TriggerMemberListPublishOperation
-  
- run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
-  
- run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
-  
- run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionClearBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionClearOperation
-  
- run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionCompareAndRemoveOperation
-  
- run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionContainsOperation
-  
- run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionGetAllOperation
-  
- run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionIsEmptyOperation
-  
- run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveOperation
-  
- run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionReplicationOperation
-  
- run() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionSizeOperation
-  
- run() - Method in class com.hazelcast.collection.impl.list.operations.ListAddAllOperation
-  
- run() - Method in class com.hazelcast.collection.impl.list.operations.ListAddOperation
-  
- run() - Method in class com.hazelcast.collection.impl.list.operations.ListGetOperation
-  
- run() - Method in class com.hazelcast.collection.impl.list.operations.ListIndexOfOperation
-  
- run() - Method in class com.hazelcast.collection.impl.list.operations.ListRemoveOperation
-  
- run() - Method in class com.hazelcast.collection.impl.list.operations.ListSetBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.list.operations.ListSetOperation
-  
- run() - Method in class com.hazelcast.collection.impl.list.operations.ListSubOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.AddAllBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.AddAllOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.CheckAndEvictOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.ClearBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.ClearOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.ContainsOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.DrainBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.DrainOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.IsEmptyOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.IteratorOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.OfferBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.PeekOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.PollBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.QueueReplicationOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.RemainingCapacityOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.RemoveBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.RemoveOperation
-  
- run() - Method in class com.hazelcast.collection.impl.queue.operations.SizeOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveAddOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionReserveRemoveOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTransactionRollbackOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.QueueTransactionRollbackOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPeekOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackBackupOperation
-  
- run() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.AlterAndGetOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.AlterOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAlterOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.SetBackupOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.SetOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.AlterAndGetOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.AlterOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndAlterOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.IsNullOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetBackupOperation
-  
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetOperation
-  
- run() - Method in class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
-  
- run() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
-  
- run() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
-  
- run() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
-  
- run() - Method in class com.hazelcast.concurrent.countdownlatch.operations.GetCountOperation
-  
- run() - Method in class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
-  
- run() - Method in class com.hazelcast.concurrent.lock.operations.AwaitBackupOperation
-  
- run() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
-  
- run() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitBackupOperation
-  
- run() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
-  
- run() - Method in class com.hazelcast.concurrent.lock.operations.GetLockCountOperation
-  
- run() - Method in class com.hazelcast.concurrent.lock.operations.GetRemainingLeaseTimeOperation
-  
- run() - Method in class com.hazelcast.concurrent.lock.operations.IsLockedOperation
-  
- run() - Method in class com.hazelcast.concurrent.lock.operations.LocalLockCleanupOperation
-  
- run() - Method in class com.hazelcast.concurrent.lock.operations.LockBackupOperation
-  
- run() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
-  
- run() - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
-  
- run() - Method in class com.hazelcast.concurrent.lock.operations.UnlockBackupOperation
-  
- run() - Method in class com.hazelcast.concurrent.lock.operations.UnlockIfLeaseExpiredOperation
-  
- run() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
-  
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireBackupOperation
-  
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
-  
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.AvailableOperation
-  
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.DeadMemberBackupOperation
-  
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainBackupOperation
-  
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainOperation
-  
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.InitBackupOperation
-  
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.InitOperation
-  
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceBackupOperation
-  
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
-  
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseBackupOperation
-  
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
-  
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-  
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
-  
- run() - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
-  
- run() - Method in class com.hazelcast.executor.impl.operations.ShutdownOperation
-  
- run() - Method in class com.hazelcast.instance.Node.NodeShutdownHookThread
-  
- run() - Method in class com.hazelcast.internal.management.operation.ChangeWanStateOperation
-  
- run() - Method in class com.hazelcast.internal.management.operation.GetMapConfigOperation
-  
- run() - Method in class com.hazelcast.internal.management.operation.ScriptExecutorOperation
-  
- run() - Method in class com.hazelcast.internal.management.operation.ThreadDumpOperation
-  
- run() - Method in class com.hazelcast.internal.management.operation.UpdateManagementCenterUrlOperation
-  
- run() - Method in class com.hazelcast.internal.management.operation.UpdateMapConfigOperation
-  
- run() - Method in class com.hazelcast.map.impl.mapstore.writebehind.StoreWorker
-  
- run() - Method in class com.hazelcast.map.impl.operation.AddIndexOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.ClearBackupOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.ClearExpiredOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.ClearNearCacheOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.ClearOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.ContainsKeyOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.ContainsValueOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.DeleteOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.EntryBackupOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.EntryOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.EvictAllBackupOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.EvictOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.GetAllOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.GetEntryViewOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.GetOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.LoadAllOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.LoadMapOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.LoadStatusOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.MapFlushBackupOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.MapFlushOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.MapIsEmptyOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.MapPartitionDestroyTask
-  
- run() - Method in class com.hazelcast.map.impl.operation.MapReplicationOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.MapSizeOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.MergeOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.MultipleEntryBackupOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.NearCacheBatchInvalidationOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.NearCacheSingleInvalidationOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.PartitionCheckIfLoadedOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryBackupOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.PutAllBackupOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllBackupOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.PutIfAbsentOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.PutOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.PutTransientOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.RemoveBackupOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.RemoveIfSameOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.RemoveOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.ReplaceOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.SetOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.TryPutOperation
-  
- run() - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
-  
- run() - Method in class com.hazelcast.map.impl.query.QueryOperation
-  
- run() - Method in class com.hazelcast.map.impl.query.QueryPartitionOperation
-  
- run() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-  
- run() - Method in class com.hazelcast.map.impl.tx.TxnLockAndGetOperation
-  
- run() - Method in class com.hazelcast.map.impl.tx.TxnPrepareBackupOperation
-  
- run() - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
-  
- run() - Method in class com.hazelcast.map.impl.tx.TxnRollbackBackupOperation
-  
- run() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
-  
- run() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-  
- run() - Method in class com.hazelcast.map.impl.tx.TxnUnlockBackupOperation
-  
- run() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-  
- run() - Method in class com.hazelcast.mapreduce.impl.operation.CancelJobSupervisorOperation
-  
- run() - Method in class com.hazelcast.mapreduce.impl.operation.FireNotificationOperation
-  
- run() - Method in class com.hazelcast.mapreduce.impl.operation.GetResultOperation
-  
- run() - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentOperation
-  
- run() - Method in class com.hazelcast.mapreduce.impl.operation.KeyValueJobOperation
-  
- run() - Method in class com.hazelcast.mapreduce.impl.operation.NotifyRemoteExceptionOperation
-  
- run() - Method in class com.hazelcast.mapreduce.impl.operation.PostPonePartitionProcessing
-  
- run() - Method in class com.hazelcast.mapreduce.impl.operation.ProcessStatsUpdateOperation
-  
- run() - Method in class com.hazelcast.mapreduce.impl.operation.RequestMemberIdAssignment
-  
- run() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionMapping
-  
- run() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionProcessed
-  
- run() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionReducing
-  
- run() - Method in class com.hazelcast.mapreduce.impl.operation.StartProcessingJobOperation
-  
- run() - Method in class com.hazelcast.mapreduce.impl.task.ReducerTask
-  
- run() - Method in class com.hazelcast.multimap.impl.operations.ClearBackupOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.operations.ClearOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.operations.CountOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.operations.EntrySetOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.operations.GetAllOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.operations.KeySetOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.operations.MultiMapMigrationOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.operations.PutBackupOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.operations.PutOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllBackupOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.operations.RemoveBackupOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.operations.RemoveOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.operations.SizeOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.operations.ValuesOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitBackupOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnGenerateRecordIdOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareBackupOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnPutBackupOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllBackupOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveBackupOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackBackupOperation
-  
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackOperation
-  
- run() - Method in class com.hazelcast.nio.tcp.InitConnectionTask
-  
- run() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingIOThread
-  
- run() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingSocketWriter
-  
- run() - Method in class com.hazelcast.nio.tcp.SocketAcceptorThread
-  
- run() - Method in class com.hazelcast.nio.tcp.spinning.SpinningInputThread
-  
- run() - Method in class com.hazelcast.nio.tcp.spinning.SpinningOutputThread
-  
- run() - Method in class com.hazelcast.partition.impl.AssignPartitions
-  
- run() - Method in class com.hazelcast.partition.impl.CheckReplicaVersion
-  
- run() - Method in class com.hazelcast.partition.impl.HasOngoingMigration
-  
- run() - Method in class com.hazelcast.partition.impl.IsReplicaVersionSync
-  
- run() - Method in class com.hazelcast.partition.impl.MigrationOperation
-  
- run() - Method in class com.hazelcast.partition.impl.MigrationRequestOperation
-  
- run() - Method in class com.hazelcast.partition.impl.PartitionStateOperation
-  
- run() - Method in class com.hazelcast.partition.impl.ReplicaSyncRequest
-  
- run() - Method in class com.hazelcast.partition.impl.ReplicaSyncResponse
-  
- run() - Method in class com.hazelcast.partition.impl.ReplicaSyncRetryResponse
-  
- run() - Method in class com.hazelcast.partition.impl.SafeStateCheckOperation
-  
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.CheckReplicaVersion
-  
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.ClearOperation
-  
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.ContainsKeyOperation
-  
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.ContainsValueOperation
-  
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.EntrySetOperation
-  
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.EvictionOperation
-  
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.GetOperation
-  
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.IsEmptyOperation
-  
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.KeySetOperation
-  
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.MergeOperation
-  
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.PutAllOperation
-  
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.PutOperation
-  
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.RemoveOperation
-  
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateOperation
-  
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateToCallerOperation
-  
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicationOperation
-  
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.RequestMapDataOperation
-  
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.SizeOperation
-  
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.SyncReplicatedMapDataOperation
-  
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.ValuesOperation
-  
- run() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllBackupOperation
-  
- run() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
-  
- run() - Method in class com.hazelcast.ringbuffer.impl.operations.AddBackupOperation
-  
- run() - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
-  
- run() - Method in class com.hazelcast.ringbuffer.impl.operations.GenericOperation
-  
- run() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadManyOperation
-  
- run() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadOneOperation
-  
- run() - Method in class com.hazelcast.ringbuffer.impl.operations.ReplicationOperation
-  
- run() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventProcessor
-  
- run() - Method in class com.hazelcast.spi.impl.eventservice.impl.LocalEventDispatcher
-  
- run() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.DeregistrationOperation
-  
- run() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.PostJoinRegistrationOperation
-  
- run() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.RegistrationOperation
-  
- run() - Method in class com.hazelcast.spi.impl.eventservice.impl.operations.SendEventOperation
-  
- run() - Method in class com.hazelcast.spi.impl.eventservice.impl.RemoteEventProcessor
-  
- run() - Method in class com.hazelcast.spi.impl.operationexecutor.classic.OperationThread
-  
- run(Packet) - Method in class com.hazelcast.spi.impl.operationexecutor.OperationRunner
-  
- run(Runnable) - Method in class com.hazelcast.spi.impl.operationexecutor.OperationRunner
-  
- run(Operation) - Method in class com.hazelcast.spi.impl.operationexecutor.OperationRunner
-  
- run() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
-  
- run() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.IsStillExecutingOperation
-  
- run() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation
-  
- run() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.TraceableIsStillExecutingOperation
-  
- run() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.DistributedObjectDestroyOperation
-  
- run() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.InitializeDistributedObjectOperation
-  
- run() - Method in class com.hazelcast.spi.impl.proxyservice.impl.operations.PostJoinProxyOperation
-  
- run() - Method in class com.hazelcast.spi.Operation
-  
- run() - Method in class com.hazelcast.topic.impl.PublishOperation
-  
- run() - Method in class com.hazelcast.transaction.impl.operations.BroadcastTxRollbackOperation
-  
- run() - Method in class com.hazelcast.transaction.impl.operations.CreateAllowedDuringPassiveStateTxBackupLogOperation
-  
- run() - Method in class com.hazelcast.transaction.impl.operations.CreateTxBackupLogOperation
-  
- run() - Method in class com.hazelcast.transaction.impl.operations.PurgeTxBackupLogOperation
-  
- run() - Method in class com.hazelcast.transaction.impl.operations.ReplicateTxBackupLogOperation
-  
- run() - Method in class com.hazelcast.transaction.impl.operations.RollbackTxBackupLogOperation
-  
- run() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionBackupOperation
-  
- run() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
-  
- run() - Method in class com.hazelcast.transaction.impl.xa.operations.CollectRemoteTransactionsOperation
-  
- run() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionBackupOperation
-  
- run() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
-  
- run() - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionBackupOperation
-  
- run() - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionOperation
-  
- run() - Method in class com.hazelcast.transaction.impl.xa.operations.XaReplicationOperation
-  
- run() - Method in class com.hazelcast.util.executor.CompletableFutureTask
-  
- run() - Method in class com.hazelcast.util.executor.HazelcastManagedThread
- 
Manages the thread lifecycle and can be overridden to customize if needed. 
- RunGcRequest - Class in com.hazelcast.internal.management.request
- 
Request for invoking Garbage Collection on the node. 
- RunGcRequest() - Constructor for class com.hazelcast.internal.management.request.RunGcRequest
-  
- RunnableAdapter<V> - Class in com.hazelcast.executor.impl
- 
- RunnableAdapter() - Constructor for class com.hazelcast.executor.impl.RunnableAdapter
-  
- RunnableAdapter(Runnable) - Constructor for class com.hazelcast.executor.impl.RunnableAdapter
-  
- runningOperationsCount - Variable in class com.hazelcast.internal.management.dto.OperationServiceDTO
-  
- runOnAllPartitionThreads(Runnable) - Method in class com.hazelcast.spi.impl.operationexecutor.classic.ClassicOperationExecutor
-  
- runOnAllPartitionThreads(Runnable) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
- 
Executes the task on all partition operation threads. 
- runOnCallingThread(Operation) - Method in class com.hazelcast.spi.impl.operationexecutor.classic.ClassicOperationExecutor
-  
- runOnCallingThread(Operation) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
- 
Runs the operation on the calling thread. 
- runOnCallingThreadIfPossible(Operation) - Method in class com.hazelcast.spi.impl.operationexecutor.classic.ClassicOperationExecutor
-  
- runOnCallingThreadIfPossible(Operation) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
- 
Tries to run the operation on the calling thread if possible. 
- runOperationOnCallingThread(Operation) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- runOperationOnCallingThread(Operation) - Method in interface com.hazelcast.spi.OperationService
- 
Runs an operation in the calling thread. 
- RUNTIME - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- RuntimeInterruptedException - Exception in com.hazelcast.core
- 
- RuntimeInterruptedException() - Constructor for exception com.hazelcast.core.RuntimeInterruptedException
-  
- RuntimeInterruptedException(String) - Constructor for exception com.hazelcast.core.RuntimeInterruptedException
-  
- RuntimeMemoryInfoAccessor - Class in com.hazelcast.util
- 
Provides memory information using  Runtime. 
- RuntimeMemoryInfoAccessor() - Constructor for class com.hazelcast.util.RuntimeMemoryInfoAccessor
-  
- RuntimeMetricSet - Class in com.hazelcast.internal.metrics.metricsets
- 
A Metric pack for exposing  Runtime metrics. 
- runUnderLifecycleLock(Runnable) - Method in class com.hazelcast.instance.LifecycleServiceImpl
-  
- SafeBuffer - Class in com.hazelcast.client.impl.protocol.util
- 
Implementation of ClientProtocolBuffer that is used by default in clients. 
- SafeBuffer(byte[]) - Constructor for class com.hazelcast.client.impl.protocol.util.SafeBuffer
-  
- safeRegister(Class, Serializer) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- safeRegister(Class, SerializerAdapter) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- SafeStateCheckOperation - Class in com.hazelcast.partition.impl
- 
Checks whether a node is safe or not. 
- SafeStateCheckOperation() - Constructor for class com.hazelcast.partition.impl.SafeStateCheckOperation
-  
- sample(int) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.HeapNearCacheRecordMap
-  
- sample(int) - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap
-  
- sample(int) - Method in interface com.hazelcast.internal.eviction.impl.strategy.sampling.SampleableEvictableStore
- 
The sample method is used to sample a number of entries (defined by the samples parameter) from
 the internal data structure. 
- SampleableCacheRecordMap<K extends Data,V extends CacheRecord> - Interface in com.hazelcast.cache.impl.record
-  
- SampleableConcurrentHashMap<K,V> - Class in com.hazelcast.util
- 
ConcurrentHashMap to extend iterator capability. 
- SampleableConcurrentHashMap(int) - Constructor for class com.hazelcast.util.SampleableConcurrentHashMap
-  
- SampleableConcurrentHashMap(int, float, int, ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType, EnumSet<ConcurrentReferenceHashMap.Option>) - Constructor for class com.hazelcast.util.SampleableConcurrentHashMap
-  
- SampleableConcurrentHashMap.SamplingEntry - Class in com.hazelcast.util
- 
Entry to define keys and values for sampling. 
- SampleableConcurrentHashMap.SamplingEntry(K, V) - Constructor for class com.hazelcast.util.SampleableConcurrentHashMap.SamplingEntry
-  
- SampleableEvictableStore<A,E extends Evictable> - Interface in com.hazelcast.internal.eviction.impl.strategy.sampling
- 
Interface for sampleable store implementations that holds  Evictable entries to evict. 
- SampleableNearCacheRecordMap<K,V extends NearCacheRecord> - Interface in com.hazelcast.cache.impl.nearcache.impl
- 
Contract point for all record maps these supports entry sampling to be used for storage in near-cache. 
- SamplingBasedEvictionStrategy<A,E extends Evictable,S extends SampleableEvictableStore<A,E>> - Class in com.hazelcast.internal.eviction.impl.strategy.sampling
- 
- SamplingBasedEvictionStrategy() - Constructor for class com.hazelcast.internal.eviction.impl.strategy.sampling.SamplingBasedEvictionStrategy
-  
- saveEntryIndex(QueryableEntry, Object) - Method in interface com.hazelcast.query.impl.Index
- 
Add entry to this index. 
- saveEntryIndex(QueryableEntry, Object) - Method in class com.hazelcast.query.impl.Indexes
-  
- saveEntryIndex(QueryableEntry, Object) - Method in class com.hazelcast.query.impl.IndexImpl
-  
- scanAndRegister(S, String) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
-  
- scanAndRegister(S, String) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
- 
Scans the source object for any fields/methods that have been annotated with  Probe annotation, and
 registering these fields/methods as probes instances. 
- schedule(Runnable, long, TimeUnit) - Method in interface com.hazelcast.client.spi.ClientExecutionService
-  
- schedule(Runnable, long, TimeUnit) - Method in class com.hazelcast.client.spi.impl.ClientExecutionServiceImpl
- 
Utilized when given command needs to make a remote call. 
- schedule(Runnable, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
-  
- schedule(String, Runnable, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
-  
- schedule(Runnable, long, TimeUnit) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-  
- schedule(String, Runnable, long, TimeUnit) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-  
- schedule(long, K, V) - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
- 
Schedules (or reschedules) the execution of given entry. 
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.client.spi.ClientExecutionService
-  
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class com.hazelcast.client.spi.impl.ClientExecutionServiceImpl
-  
- scheduleAtFixedRate(Runnable, long, TimeUnit) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
-  
- scheduleAtFixedRate(Runnable, long, TimeUnit) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
- 
Schedules a publisher to be executed at a fixed rate. 
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
-  
- scheduleAtFixedRate(String, Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
-  
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-  
- scheduleAtFixedRate(String, Runnable, long, long, TimeUnit) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-  
- SCHEDULED_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
- 
Name of the scheduled executor. 
- ScheduledEntry<K,V> - Class in com.hazelcast.util.scheduler
- 
Entry wrapper with schedule time information to be used in SecondsBasedEntryTaskScheduler. 
- ScheduledEntry(K, V, long, int, long) - Constructor for class com.hazelcast.util.scheduler.ScheduledEntry
-  
- ScheduledEntryProcessor<K,V> - Interface in com.hazelcast.util.scheduler
-  
- scheduleEviction(String, long) - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- scheduleExpirationTask(NearCacheExecutor, DefaultNearCache<K, V>.ExpirationTask) - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache
-  
- ScheduleQueue - Interface in com.hazelcast.spi.impl.operationexecutor.classic
- 
The ScheduleQueue is a kind of priority queue where 'tasks' are queued for scheduling. 
- scheduleTtlEntry(long, Object, Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-  
- scheduleTtlEntry(long, Object, Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- ScheduleType - Enum in com.hazelcast.util.scheduler
- 
Controls behaviour of SecondsBasedEntryTaskSchedulerwhen a new entry is added
 under already existing key.
 
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheExecutor
- 
Creates and executes a periodic action that becomes enabled first after the given initial delay. 
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.client.spi.ClientExecutionService
-  
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class com.hazelcast.client.spi.impl.ClientExecutionServiceImpl
-  
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
-  
- scheduleWithFixedDelay(String, Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
-  
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-  
- scheduleWithFixedDelay(String, Runnable, long, long, TimeUnit) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-  
- schemaValidation(Document) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-  
- ScriptEngineManagerContext - Class in com.hazelcast.internal.management
- 
- ScriptExecutorOperation - Class in com.hazelcast.internal.management.operation
- 
Operation to execute script on the node. 
- ScriptExecutorOperation() - Constructor for class com.hazelcast.internal.management.operation.ScriptExecutorOperation
-  
- ScriptExecutorOperation(String, String, Map<String, Object>) - Constructor for class com.hazelcast.internal.management.operation.ScriptExecutorOperation
-  
- searchForOtherClusters() - Method in class com.hazelcast.cluster.impl.MulticastJoiner
-  
- searchForOtherClusters() - Method in class com.hazelcast.cluster.impl.TcpIpJoiner
-  
- searchForOtherClusters() - Method in interface com.hazelcast.cluster.Joiner
-  
- SecureCallable<V> - Interface in com.hazelcast.security
- 
A secure callable that runs in a sandbox. 
- SecureRequest - Interface in com.hazelcast.client.impl.client
-  
- SECURITY - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- SecurityConfig - Class in com.hazelcast.config
- 
Contains configuration for Security 
- SecurityConfig() - Constructor for class com.hazelcast.config.SecurityConfig
-  
- securityContext - Variable in class com.hazelcast.instance.Node
-  
- SecurityContext - Interface in com.hazelcast.security
- 
- SecurityInterceptor - Interface in com.hazelcast.security
- 
This interface allows to intercept requests which produced by an API call like map.put, queue.offer ... 
- SecurityInterceptorConfig - Class in com.hazelcast.config
- 
- SecurityInterceptorConfig() - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
-  
- SecurityInterceptorConfig(String) - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
-  
- SecurityInterceptorConfig(SecurityInterceptor) - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
-  
- segments - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-  
- select(Member) - Method in interface com.hazelcast.core.MemberSelector
- 
Decides if the given member will be part of an operation or not. 
- selectEvictableAsPolicy(Evictable, Evictable) - Method in class com.hazelcast.internal.eviction.impl.evaluator.AbstractEvictionPolicyEvaluator
- 
Compares two evictable candidates and selects one as  EvictionPolicy rule. 
- selectEvictableAsPolicy(Evictable, Evictable) - Method in class com.hazelcast.internal.eviction.impl.evaluator.LFUEvictionPolicyEvaluator
-  
- selectEvictableAsPolicy(Evictable, Evictable) - Method in class com.hazelcast.internal.eviction.impl.evaluator.LRUEvictionPolicyEvaluator
-  
- SelectionHandler - Interface in com.hazelcast.nio.tcp.nonblocking
- 
The SelectionHandler is a callback interface that gets called by an IO-thread when there data available to read, or space
 available to write. 
- selectionKey - Variable in class com.hazelcast.nio.tcp.nonblocking.AbstractHandler
-  
- SelectorMode - Enum in com.hazelcast.nio.tcp.nonblocking
- 
Controls the mode in which IO and acceptor thread selectors will be operating 
- selectToSave(Object...) - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache
-  
- selectToSave(Object...) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.NearCacheDataRecordStore
-  
- selectToSave(Object...) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.NearCacheObjectRecordStore
-  
- selectToSave(Object...) - Method in interface com.hazelcast.cache.impl.nearcache.NearCache
- 
Selects the best candidate object to store from the given candidates.
 
- selectToSave(Object...) - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheRecordStore
- 
Selects the best candidate object to store from the given candidates.
 
- selectToSave(Object...) - Method in class com.hazelcast.client.map.impl.nearcache.ClientHeapNearCache
-  
- selectToSave(Object...) - Method in class com.hazelcast.map.impl.nearcache.NearCacheImpl
-  
- SEMAPHORE_DEAD_MEMBER_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-  
- SEMAPHORE_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- SEMAPHORE_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- SEMAPHORE_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- SEMAPHORE_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- SEMAPHORE_REPLICATION_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-  
- SemaphoreAcquireMessageTask - Class in com.hazelcast.client.impl.protocol.task.semaphore
-  
- SemaphoreAcquireMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreAcquireMessageTask
-  
- SemaphoreAvailablePermitsMessageTasks - Class in com.hazelcast.client.impl.protocol.task.semaphore
-  
- SemaphoreAvailablePermitsMessageTasks(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreAvailablePermitsMessageTasks
-  
- SemaphoreBackupAwareOperation - Class in com.hazelcast.concurrent.semaphore.operations
-  
- SemaphoreBackupAwareOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupAwareOperation
-  
- SemaphoreBackupAwareOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupAwareOperation
-  
- SemaphoreBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
-  
- SemaphoreBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupOperation
-  
- SemaphoreBackupOperation(String, int, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupOperation
-  
- SemaphoreConfig - Class in com.hazelcast.config
- 
- SemaphoreConfig() - Constructor for class com.hazelcast.config.SemaphoreConfig
- 
- SemaphoreConfig(SemaphoreConfig) - Constructor for class com.hazelcast.config.SemaphoreConfig
- 
Creates a SemaphoreConfig by cloning another one. 
- SemaphoreConfigReadOnly - Class in com.hazelcast.config
- 
Contains configuration for Semaphore(read only) 
- SemaphoreConfigReadOnly(SemaphoreConfig) - Constructor for class com.hazelcast.config.SemaphoreConfigReadOnly
-  
- SemaphoreContainer - Class in com.hazelcast.concurrent.semaphore
-  
- SemaphoreContainer() - Constructor for class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-  
- SemaphoreContainer(int, SemaphoreConfig) - Constructor for class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-  
- SemaphoreDataSerializerHook - Class in com.hazelcast.concurrent.semaphore
-  
- SemaphoreDataSerializerHook() - Constructor for class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-  
- SemaphoreDeadMemberOperation - Class in com.hazelcast.concurrent.semaphore.operations
-  
- SemaphoreDeadMemberOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-  
- SemaphoreDeadMemberOperation(String, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-  
- SemaphoreDrainPermitsMessageTask - Class in com.hazelcast.client.impl.protocol.task.semaphore
-  
- SemaphoreDrainPermitsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreDrainPermitsMessageTask
-  
- SemaphoreInitMessageTask - Class in com.hazelcast.client.impl.protocol.task.semaphore
-  
- SemaphoreInitMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreInitMessageTask
-  
- SemaphoreMBean - Class in com.hazelcast.jmx
- 
- SemaphoreMBean(ISemaphore, ManagementService) - Constructor for class com.hazelcast.jmx.SemaphoreMBean
-  
- SemaphoreOperation - Class in com.hazelcast.concurrent.semaphore.operations
-  
- SemaphoreOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
-  
- SemaphoreOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
-  
- SemaphorePermission - Class in com.hazelcast.security.permission
-  
- SemaphorePermission(String, String...) - Constructor for class com.hazelcast.security.permission.SemaphorePermission
-  
- SemaphorePortableHook - Class in com.hazelcast.concurrent.semaphore.client
-  
- SemaphorePortableHook() - Constructor for class com.hazelcast.concurrent.semaphore.client.SemaphorePortableHook
-  
- SemaphoreProxy - Class in com.hazelcast.concurrent.semaphore
-  
- SemaphoreProxy(String, SemaphoreService, NodeEngine) - Constructor for class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-  
- SemaphoreReducePermitsMessageTask - Class in com.hazelcast.client.impl.protocol.task.semaphore
-  
- SemaphoreReducePermitsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreReducePermitsMessageTask
-  
- SemaphoreReleaseMessageTask - Class in com.hazelcast.client.impl.protocol.task.semaphore
-  
- SemaphoreReleaseMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreReleaseMessageTask
-  
- SemaphoreReplicationOperation - Class in com.hazelcast.concurrent.semaphore.operations
-  
- SemaphoreReplicationOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
-  
- SemaphoreReplicationOperation(Map<String, SemaphoreContainer>) - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
-  
- SemaphoreRequest - Class in com.hazelcast.concurrent.semaphore.client
-  
- SemaphoreRequest() - Constructor for class com.hazelcast.concurrent.semaphore.client.SemaphoreRequest
-  
- SemaphoreRequest(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.client.SemaphoreRequest
-  
- SemaphoreService - Class in com.hazelcast.concurrent.semaphore
-  
- SemaphoreService(NodeEngine) - Constructor for class com.hazelcast.concurrent.semaphore.SemaphoreService
-  
- SemaphoreTryAcquireMessageTask - Class in com.hazelcast.client.impl.protocol.task.semaphore
-  
- SemaphoreTryAcquireMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.semaphore.SemaphoreTryAcquireMessageTask
-  
- SemaphoreWaitNotifyKey - Class in com.hazelcast.concurrent.semaphore
-  
- SemaphoreWaitNotifyKey(String, String) - Constructor for class com.hazelcast.concurrent.semaphore.SemaphoreWaitNotifyKey
-  
- send(JoinMessage) - Method in class com.hazelcast.cluster.impl.MulticastService
-  
- send(Address, Operation) - Method in class com.hazelcast.internal.management.ManagementCenterService
-  
- send(Operation, Address) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- send(Response, Address) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- send(Operation, Address) - Method in interface com.hazelcast.spi.OperationService
- 
Executes an operation remotely. 
- send(Response, Address) - Method in interface com.hazelcast.spi.OperationService
- 
Deprecated. 
- send200() - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
-  
- send204() - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
-  
- send400() - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
-  
- sendClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- sendClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-  
- sendClientMessage(Object, ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-  
- sendClientMessage(Throwable) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-  
- sendEvent(Object, Object, long) - Method in interface com.hazelcast.client.ClientEndpoint
-  
- sendEvent(Object, Object, long) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- SendEventOperation - Class in com.hazelcast.spi.impl.eventservice.impl.operations
-  
- SendEventOperation() - Constructor for class com.hazelcast.spi.impl.eventservice.impl.operations.SendEventOperation
-  
- SendEventOperation(EventEnvelope, int) - Constructor for class com.hazelcast.spi.impl.eventservice.impl.operations.SendEventOperation
-  
- sendInvalidationEvent(String, Data, String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
- 
Sends an invalidation event for given cacheNamewith specifiedkeyfrom mentioned source withsourceUuid.
 
- sendInvalidationEvent(String, Data, String) - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- sendJoinRequest(Address, boolean) - Method in class com.hazelcast.cluster.impl.ClusterJoinManager
-  
- sendKeys(MapStoreContext, boolean) - Method in class com.hazelcast.map.impl.MapKeyLoader
- 
Sends keys to all partitions in batches. 
- sendMasterConfirmation() - Method in class com.hazelcast.cluster.impl.ClusterHeartbeatManager
-  
- sendMasterQuestion(Address) - Method in class com.hazelcast.cluster.impl.ClusterJoinManager
-  
- sendMemberListToMember(Address) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- sendNotification(Notification) - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-  
- sendNotification(Address, MapReduceNotification) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-  
- sendReplicationOperation(boolean) - Method in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
-  
- sendReplicationOperation(boolean, String, Data, Data, long, VersionResponsePair) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-  
- sendResponse(Object, long) - Method in interface com.hazelcast.client.ClientEndpoint
-  
- sendResponse(Object, long) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- sendResponse(ClientEndpoint, Object, Object, long, boolean, boolean) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- sendResponse(Object) - Method in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-  
- sendResponse - Variable in class com.hazelcast.cluster.impl.operations.MemberInfoUpdateOperation
-  
- sendResponse(TextCommand) - Method in interface com.hazelcast.internal.ascii.TextCommandService
-  
- sendResponse(TextCommand) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- sendResponse(TextCommand) - Method in class com.hazelcast.nio.ascii.TextReadHandler
-  
- sendResponse(Operation, Object) - Method in class com.hazelcast.spi.impl.operationservice.impl.RemoteInvocationResponseHandler
-  
- sendResponse(Object) - Method in class com.hazelcast.spi.Operation
-  
- sendResponse(O, Object) - Method in interface com.hazelcast.spi.OperationResponseHandler
- 
Sends a response. 
- sendResponse(Object) - Method in interface com.hazelcast.spi.ResponseHandler
- 
Deprecated. 
- sendShutdownMessage() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- sendUpdateCallerOperation(boolean) - Method in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
-  
- Sequenced - Interface in com.hazelcast.map.impl.querycache.event.sequence
- 
This interface should be implemented by events which need a sequence number. 
- SerializableList - Class in com.hazelcast.spi.impl
-  
- SerializableList() - Constructor for class com.hazelcast.spi.impl.SerializableList
-  
- SerializableList(List<Data>) - Constructor for class com.hazelcast.spi.impl.SerializableList
-  
- SerializableXID - Class in com.hazelcast.transaction.impl.xa
-  
- SerializableXID() - Constructor for class com.hazelcast.transaction.impl.xa.SerializableXID
-  
- SerializableXID(int, byte[], byte[]) - Constructor for class com.hazelcast.transaction.impl.xa.SerializableXID
-  
- SerializationConfig - Class in com.hazelcast.config
- 
- SerializationConfig() - Constructor for class com.hazelcast.config.SerializationConfig
-  
- SerializationConstants - Class in com.hazelcast.internal.serialization.impl
-  
- serializationService - Variable in class com.hazelcast.cache.impl.CacheRecordStore
-  
- serializationService - Variable in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache
-  
- serializationService - Variable in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- serializationService - Variable in class com.hazelcast.cache.impl.record.CacheRecordFactory
-  
- serializationService - Variable in class com.hazelcast.client.impl.client.ClientRequest
-  
- serializationService - Variable in class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-  
- serializationService - Variable in class com.hazelcast.client.spi.impl.listener.ClientListenerServiceImpl
-  
- serializationService - Variable in class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolImpl
-  
- SerializationService - Interface in com.hazelcast.internal.serialization
-  
- serializationService - Variable in class com.hazelcast.map.impl.event.MapEventPublisherImpl
-  
- serializationService - Variable in class com.hazelcast.map.impl.MapContainer
-  
- serializationService - Variable in class com.hazelcast.map.impl.query.MapQueryEngineImpl
-  
- serializationService - Variable in class com.hazelcast.query.impl.QueryableEntry
-  
- serializationService - Variable in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-  
- SerializationServiceBuilder - Interface in com.hazelcast.internal.serialization
-  
- SerializationServiceSupport - Interface in com.hazelcast.spi.impl
-  
- SerializationServiceV1 - Class in com.hazelcast.internal.serialization.impl
-  
- SerializationUtil - Class in com.hazelcast.internal.serialization.impl
-  
- serializer - Variable in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-  
- Serializer - Interface in com.hazelcast.nio.serialization
- 
- SerializerConfig - Class in com.hazelcast.config
- 
Contains the serialization configuration for a particular class. 
- SerializerConfig() - Constructor for class com.hazelcast.config.SerializerConfig
-  
- serializerFor(int) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- serializerFor(Object) - Method in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-  
- SerializerHook<T> - Interface in com.hazelcast.nio.serialization
- 
- SERVER_ERROR - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
-  
- ServerLifecycleListener - Class in com.hazelcast.web.listener
- 
Listens Lifecycle Events for client instance, if client is in shutdown state
  ClusteredSessionService is notified with failed connection 
- ServerLifecycleListener(ClusteredSessionService) - Constructor for class com.hazelcast.web.listener.ServerLifecycleListener
-  
- service - Variable in class com.hazelcast.client.impl.client.ClientRequest
-  
- SERVICE_NAME - Static variable in interface com.hazelcast.cache.impl.ICacheService
-  
- SERVICE_NAME - Static variable in class com.hazelcast.client.impl.ClientEngineImpl
- 
Service name to be used in requests. 
- SERVICE_NAME - Static variable in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- SERVICE_NAME - Static variable in class com.hazelcast.collection.impl.list.ListService
-  
- SERVICE_NAME - Static variable in class com.hazelcast.collection.impl.queue.QueueService
-  
- SERVICE_NAME - Static variable in class com.hazelcast.collection.impl.set.SetService
-  
- SERVICE_NAME - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-  
- SERVICE_NAME - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-  
- SERVICE_NAME - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-  
- SERVICE_NAME - Static variable in class com.hazelcast.concurrent.idgen.IdGeneratorService
-  
- SERVICE_NAME - Static variable in interface com.hazelcast.concurrent.lock.LockService
-  
- SERVICE_NAME - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreService
-  
- SERVICE_NAME - Static variable in class com.hazelcast.executor.impl.DistributedExecutorService
-  
- SERVICE_NAME - Static variable in class com.hazelcast.map.impl.MapService
-  
- SERVICE_NAME - Static variable in class com.hazelcast.mapreduce.impl.MapReduceService
-  
- SERVICE_NAME - Static variable in class com.hazelcast.multimap.impl.MultiMapService
-  
- SERVICE_NAME - Static variable in interface com.hazelcast.partition.InternalPartitionService
-  
- SERVICE_NAME - Static variable in class com.hazelcast.quorum.impl.QuorumServiceImpl
-  
- SERVICE_NAME - Static variable in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- SERVICE_NAME - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferService
-  
- SERVICE_NAME - Static variable in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-  
- SERVICE_NAME - Static variable in class com.hazelcast.topic.impl.reliable.ReliableTopicService
-  
- SERVICE_NAME - Static variable in class com.hazelcast.topic.impl.TopicService
-  
- SERVICE_NAME - Static variable in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-  
- SERVICE_NAME - Static variable in class com.hazelcast.transaction.impl.xa.XAService
-  
- SERVICE_NAME - Static variable in interface com.hazelcast.wan.WanReplicationService
- 
Service name. 
- ServiceConfig - Class in com.hazelcast.config
-  
- ServiceConfig() - Constructor for class com.hazelcast.config.ServiceConfig
-  
- ServiceConfigurationParser<T> - Interface in com.hazelcast.spi
- 
A hook into the parsing system. 
- ServiceInfo - Class in com.hazelcast.spi.impl.servicemanager
- 
Contains the name of the service and the actual service. 
- ServiceInfo(String, Object) - Constructor for class com.hazelcast.spi.impl.servicemanager.ServiceInfo
-  
- ServiceLoader - Class in com.hazelcast.util
- 
Support class for loading Hazelcast services and hooks based on the Java ServiceLoader specification
 but changed in the fact of classloaders to test for given services to work in multi classloader
 environments like application or OSGi servers 
- ServiceManager - Interface in com.hazelcast.spi.impl.servicemanager
- 
Responsible for managing services. 
- ServiceManagerImpl - Class in com.hazelcast.spi.impl.servicemanager.impl
-  
- ServiceManagerImpl(NodeEngineImpl) - Constructor for class com.hazelcast.spi.impl.servicemanager.impl.ServiceManagerImpl
-  
- serviceName - Variable in class com.hazelcast.collection.impl.collection.client.CollectionRequest
-  
- serviceName - Variable in class com.hazelcast.spi.InvocationBuilder
-  
- ServicesConfig - Class in com.hazelcast.config
-  
- ServicesConfig() - Constructor for class com.hazelcast.config.ServicesConfig
-  
- servletContext - Variable in class com.hazelcast.web.WebFilter
-  
- SESSION_DELETE - Static variable in class com.hazelcast.web.WebDataSerializerHook
- 
The constant SESSION_DELETE. 
- SESSION_STATE - Static variable in class com.hazelcast.web.WebDataSerializerHook
- 
The constant SESSION_STATE. 
- SESSION_UPDATE - Static variable in class com.hazelcast.web.WebDataSerializerHook
- 
The constant SESSION_UPDATE. 
- sessionChanged() - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- sessionCreated(HttpSessionEvent) - Method in class com.hazelcast.web.SessionListener
-  
- sessionDestroyed(HttpSessionEvent) - Method in class com.hazelcast.web.SessionListener
-  
- SessionListener - Class in com.hazelcast.web
- 
Pairs with  WebFilter to notify it of  HttpSession timeouts. 
- SessionListener() - Constructor for class com.hazelcast.web.SessionListener
-  
- sessionRegistry - Variable in class com.hazelcast.web.spring.SpringAwareWebFilter
-  
- SessionState - Class in com.hazelcast.web
- 
Wrapper class which holds session attributes 
- SessionState() - Constructor for class com.hazelcast.web.SessionState
-  
- SessionUpdateEntryProcessor - Class in com.hazelcast.web.entryprocessor
- 
Entry processor which updates SessionState attributes stored in distributed map
 If value of attribute is set to null. 
- SessionUpdateEntryProcessor(int) - Constructor for class com.hazelcast.web.entryprocessor.SessionUpdateEntryProcessor
-  
- SessionUpdateEntryProcessor(String, Data) - Constructor for class com.hazelcast.web.entryprocessor.SessionUpdateEntryProcessor
-  
- SessionUpdateEntryProcessor() - Constructor for class com.hazelcast.web.entryprocessor.SessionUpdateEntryProcessor
-  
- set(boolean) - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- set(byte) - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- set(int) - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- set(long) - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- set(String) - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- set(Data) - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- set(byte[]) - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- set(Collection<Data>) - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- set(Map.Entry<Data, Data>) - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-  
- set(long) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-  
- set(E) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-  
- set(int, E) - Method in class com.hazelcast.client.proxy.ClientListProxy
-  
- set(K, V, long, TimeUnit) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- set(K, V) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- set(K, V) - Method in class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-  
- set(K, V) - Method in class com.hazelcast.client.txn.proxy.ClientTxnMapProxy
-  
- set(int, long, Data) - Method in class com.hazelcast.collection.impl.list.ListContainer
-  
- set(int, E) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
-  
- set(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
-  
- set(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-  
- set(Data) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceContainer
-  
- SET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-  
- set(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- set(K, V) - Method in interface com.hazelcast.core.BaseMap
- 
Associates the specified value with the specified key in this map. 
- set(long) - Method in interface com.hazelcast.core.IAtomicLong
- 
Atomically sets the given value. 
- set(E) - Method in interface com.hazelcast.core.IAtomicReference
- 
Atomically sets the given value. 
- set(K, V) - Method in interface com.hazelcast.core.IMap
- 
Puts an entry into this map. 
- set(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
- 
Puts an entry into this map with a given ttl (time to live) value. 
- set(K, V) - Method in interface com.hazelcast.core.TransactionalMap
- 
- set(long) - Method in class com.hazelcast.jmx.AtomicLongMBean
-  
- SET - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- set(K, V) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- set(K, V, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- set(Data, Object, long) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- set(Data, Object, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
- 
Returns trueif key doesn't exist previously, otherwise returnsfalse.
 
- set(Object, Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-  
- SET - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- SET - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-  
- set(T, long) - Method in class com.hazelcast.util.ItemCounter
- 
Set counter of item to value 
- set(E) - Method in class com.hazelcast.util.UnmodifiableListIterator
-  
- set(Map<String, Data>) - Method in class com.hazelcast.web.SessionState
-  
- SET_ADAPTER - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- SET_ALL_LISTENER_FLAGS - Static variable in class com.hazelcast.map.impl.MapListenerFlagOperator
- 
Sets all listener flags. 
- SET_AND_GET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-  
- SET_BACKUP - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-  
- SET_BACKUP - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-  
- SET_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- SET_COUNT_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-  
- SET_OPERATION - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-  
- SET_REPLICATION - Static variable in class com.hazelcast.collection.impl.collection.CollectionDataSerializerHook
-  
- setAccessHit(long) - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- setAccessHit(int) - Method in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-  
- setAccessHit(int) - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheRecord
- 
- setAccessHit(int) - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-  
- setAccessHit(int) - Method in interface com.hazelcast.cache.impl.record.CacheRecord
- 
- setAccessKey(String) - Method in class com.hazelcast.config.AwsConfig
- 
Sets the access key to access AWS. 
- setAccessTime(long) - Method in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-  
- setAccessTime(long) - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheRecord
- 
Sets the access time of this  Evictable in milliseconds. 
- setAccessTime(long) - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-  
- setAccessTime(long) - Method in interface com.hazelcast.cache.impl.record.CacheRecord
- 
Sets the access time of this  Evictable in milliseconds. 
- setAcknowledgeType(WanAcknowledgeType) - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- setAcknowledgeType(WanAcknowledgeType) - Method in class com.hazelcast.wan.WanReplicationEvent
-  
- setActions(Set<String>) - Method in class com.hazelcast.config.PermissionConfig
-  
- setActivePartitionCount(int) - Method in class com.hazelcast.internal.management.dto.PartitionServiceBeanDTO
-  
- SetAdapter<E> - Class in com.hazelcast.mapreduce.aggregation.impl
- 
A simple adapter class to serialize values of a  Set using
 Hazelcast serialization support. 
- SetAdapter() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.SetAdapter
-  
- SetAddAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
- 
SetAddAllMessageTask 
- SetAddAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetAddAllMessageTask
-  
- SetAddListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
- 
SetAddListenerMessageTask 
- SetAddListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetAddListenerMessageTask
-  
- SetAddMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
- 
SetAddMessageTask 
- SetAddMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetAddMessageTask
-  
- setAddress(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- setAddress(String[]) - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
-  
- setAddresses(List<String>) - Method in class com.hazelcast.client.config.ClientConfig
- 
Deprecated. 
- setAddresses(List<String>) - Method in class com.hazelcast.client.config.ClientNetworkConfig
- 
Adds given addresses to candidate address list that client will use to establish initial connection 
- setAlgorithm(String) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-  
- setAllocatorType(NativeMemoryConfig.MemoryAllocatorType) - Method in class com.hazelcast.config.NativeMemoryConfig
-  
- setAllowUnsafe(boolean) - Method in class com.hazelcast.config.SerializationConfig
- 
Unsafe, it is not public api of java. 
- setAllowUnsafe(boolean) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- setAllowUnsafe(boolean) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
-  
- setAnchor(PagingPredicate, int, Map.Entry) - Static method in class com.hazelcast.query.PagingPredicateAccessor
-  
- setAndGet(E) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-  
- setAndGet(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-  
- setAndGet(E) - Method in interface com.hazelcast.core.IAtomicReference
- 
Deprecated.
will be removed from Hazelcast 3.4 since it doesn't really serve a purpose. 
 
- setAndGetListenerFlags(ListenerAdapter) - Static method in class com.hazelcast.map.impl.MapListenerFlagOperator
- 
Sets and gets flags of implemented listener interfaces of a  MapListener. 
- SetAndGetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-  
- SetAndGetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
-  
- SetAndGetOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
-  
- setApplicationContext(ApplicationContext) - Method in class com.hazelcast.spring.context.SpringManagedContext
-  
- setAsAsync() - Method in class com.hazelcast.map.impl.client.MapGetRequest
-  
- setAsAsync() - Method in class com.hazelcast.map.impl.client.MapPutRequest
-  
- setAsAsync() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-  
- setAsMaster() - Method in class com.hazelcast.instance.Node
-  
- setAsSubmitToKey() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-  
- setAsyncBackup(boolean) - Method in class com.hazelcast.concurrent.lock.operations.BaseLockOperation
-  
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.CacheConfig
- 
Sets the number of asynchronous backups for this  ICache. 
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Sets the number of asynchronous backups for this  ICache. 
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.CollectionConfig
- 
Sets the number of asynchronous backups. 
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.ListConfigReadOnly
-  
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.MapConfig
- 
Sets the number of asynchronous backups. 
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
- 
Sets the number of asynchronous backups. 
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-  
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.QueueConfig
- 
Sets the number of asynchronous backups. 
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.QueueConfigReadOnly
-  
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.RingbufferConfig
- 
Sets the number of asynchronous backups. 
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.SemaphoreConfig
- 
Sets the number of asynchronous backups. 
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.SemaphoreConfigReadOnly
-  
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.SetConfigReadOnly
-  
- setAsyncFillup(boolean) - Method in class com.hazelcast.config.ReplicatedMapConfig
- 
True if the replicated map is available for reads before the initial
 replication is completed, false otherwise. 
- setAttribute(String) - Method in class com.hazelcast.config.MapIndexConfig
- 
Sets the attribute that is going to be indexed. 
- setAttribute(String) - Method in class com.hazelcast.config.MapIndexConfigReadOnly
-  
- setAttribute(Attribute) - Method in class com.hazelcast.jmx.HazelcastMBean
-  
- setAttribute(String) - Method in class com.hazelcast.query.PredicateBuilder
-  
- setAttribute(String, Object) - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- setAttribute(String, Data) - Method in class com.hazelcast.web.SessionState
-  
- setAttributes(Map<String, Object>) - Method in class com.hazelcast.config.MemberAttributeConfig
-  
- setAttributes(Map<String, Object>) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-  
- setAttributes(AttributeList) - Method in class com.hazelcast.jmx.HazelcastMBean
-  
- setAveAge(long) - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- setAwsConfig(ClientAwsConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
- 
Sets configuration to connect nodes in aws environment. 
- setAwsConfig(AwsConfig) - Method in class com.hazelcast.config.JoinConfig
-  
- setBackup(long, long, Data) - Method in class com.hazelcast.collection.impl.list.ListContainer
-  
- setBackupCount(int) - Method in class com.hazelcast.config.CacheConfig
- 
Sets the number of synchronous backups. 
- setBackupCount(int) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setBackupCount(int) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Sets the number of synchronous backups for this  ICache. 
- setBackupCount(int) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- setBackupCount(int) - Method in class com.hazelcast.config.CollectionConfig
- 
Sets the number of synchronous backups for this collection. 
- setBackupCount(int) - Method in class com.hazelcast.config.ListConfigReadOnly
-  
- setBackupCount(int) - Method in class com.hazelcast.config.MapConfig
- 
Number of synchronous backups. 
- setBackupCount(int) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
- 
Sets the number of synchronous backups. 
- setBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-  
- setBackupCount(int) - Method in class com.hazelcast.config.QueueConfig
- 
Sets the number of synchronous backups for this queue. 
- setBackupCount(int) - Method in class com.hazelcast.config.QueueConfigReadOnly
-  
- setBackupCount(int) - Method in class com.hazelcast.config.RingbufferConfig
- 
Sets the number of synchronous backups. 
- setBackupCount(int) - Method in class com.hazelcast.config.SemaphoreConfig
- 
Sets the number of synchronous backups. 
- setBackupCount(int) - Method in class com.hazelcast.config.SemaphoreConfigReadOnly
-  
- setBackupCount(int) - Method in class com.hazelcast.config.SetConfigReadOnly
-  
- setBackupCount(int) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
-  
- setBackupCount(int) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- setBackupCount(int) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- setBackupEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- setBackupEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- setBackupEntryMemoryCost(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- setBackupEntryMemoryCost(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- setBackupItemCount(int) - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- SetBackupOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-  
- SetBackupOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.SetBackupOperation
-  
- SetBackupOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.SetBackupOperation
-  
- SetBackupOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-  
- SetBackupOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.SetBackupOperation
-  
- SetBackupOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.SetBackupOperation
-  
- setBaseDir(File) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
- 
Sets base directory for all Hot Restart stores. 
- setBatchMaxDelayMillis(long) - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- setBatchSize(int) - Method in class com.hazelcast.config.QueryCacheConfig
- 
Sets the batch size which will be used to determine number of events to be sent in a batch to QueryCache
 
- setBatchSize(int) - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- setBeans(MXBeansDTO) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- setBinary(boolean) - Method in class com.hazelcast.config.MultiMapConfig
- 
Enables or disables binary (serialized) form for this MultiMap. 
- setBinary(boolean) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-  
- setBindings(Bindings) - Method in class com.hazelcast.osgi.impl.OSGiScriptEngineManager
- 
Follows the same behavior of @link javax.script.ScriptEngineManager#setBindings(Bindings)
 This means that the same bindings are applied to all the underlying managers. 
- setBit(byte, int) - Static method in class com.hazelcast.nio.Bits
- 
Sets n-th bit of the byte value 
- setBit(int, int) - Static method in class com.hazelcast.nio.Bits
- 
Sets n-th bit of the integer value 
- setBits(BitSet, Iterable<Integer>) - Static method in class com.hazelcast.util.BitSetUtils
- 
Set all bits on a given positions 
- setBooleanAttribute(String, boolean) - Method in class com.hazelcast.client.impl.MemberImpl
-  
- setBooleanAttribute(String, boolean) - Method in class com.hazelcast.config.MemberAttributeConfig
-  
- setBooleanAttribute(String, boolean) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-  
- setBooleanAttribute(String, boolean) - Method in interface com.hazelcast.core.Member
- 
Defines a key-value pair boolean attribute for this member that is available
 to other cluster members. 
- setBooleanAttribute(String, boolean) - Method in class com.hazelcast.instance.MemberImpl
-  
- setBufferSize(int) - Method in class com.hazelcast.client.config.SocketOptions
- 
Sets the SO_SNDBUF and SO_RCVBUF options to the specified value in KB 
- setBufferSize(int) - Method in class com.hazelcast.config.QueryCacheConfig
- 
Sets the maximum number of events which can be stored in a buffer of partition. 
- setBypassHeartbeatCheck(boolean) - Method in class com.hazelcast.client.spi.impl.ClientInvocation
-  
- setByteAttribute(String, byte) - Method in class com.hazelcast.client.impl.MemberImpl
-  
- setByteAttribute(String, byte) - Method in class com.hazelcast.config.MemberAttributeConfig
-  
- setByteAttribute(String, byte) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-  
- setByteAttribute(String, byte) - Method in interface com.hazelcast.core.Member
- 
Defines a key-value pair byte attribute for this member available
 to other cluster members. 
- setByteAttribute(String, byte) - Method in class com.hazelcast.instance.MemberImpl
-  
- setByteOrder(ByteOrder) - Method in class com.hazelcast.config.SerializationConfig
- 
Not that configuring use native byte order as enabled will override the byte order set by this method. 
- setByteOrder(ByteOrder) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- setByteOrder(ByteOrder) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
-  
- setBytes(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- setCacheConfigs(Map<String, CacheSimpleConfig>) - Method in class com.hazelcast.config.Config
-  
- setCacheDeserializedValues(CacheDeserializedValues) - Method in class com.hazelcast.config.MapConfig
- 
Configure de-serialized value caching. 
- setCacheEntryEventFilterFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-  
- setCacheEntryEventFilterFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
-  
- setCacheEntryListenerFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-  
- setCacheEntryListenerFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
-  
- setCacheEntryListeners(List<CacheSimpleEntryListenerConfig>) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
- setCacheEntryListeners(List<CacheSimpleEntryListenerConfig>) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- setCacheLoaderFactory(Factory<? extends CacheLoader<K, V>>) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setCacheLoaderFactory(Factory<? extends CacheLoader<K, V>>) - Method in interface com.hazelcast.config.CacheConfiguration
- 
Set the CacheLoaderfactory.
 
- setCacheLoaderFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Sets the factory for this CacheLoader.
 
- setCacheLoaderFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- setCacheLocalEntries(boolean) - Method in class com.hazelcast.config.NearCacheConfig
- 
True to cache local entries also. 
- setCacheLocalEntries(boolean) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
-  
- setCacheName(String) - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- setCacheWriterFactory(Factory<? extends CacheWriter<? super K, ? super V>>) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setCacheWriterFactory(Factory<? extends CacheWriter<? super K, ? super V>>) - Method in interface com.hazelcast.config.CacheConfiguration
- 
Set the CacheWriterfactory.
 
- setCacheWriterFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Sets the factory for this CacheWriter.
 
- setCacheWriterFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- setCallback(Callback<Object>) - Method in class com.hazelcast.spi.InvocationBuilder
- 
Deprecated. 
- setCallerAddress(Operation, Address) - Static method in class com.hazelcast.spi.OperationAccessor
-  
- setCallerUuid(String) - Method in class com.hazelcast.spi.Operation
-  
- setCallId(long) - Method in class com.hazelcast.client.impl.client.ClientRequest
-  
- setCallId(Operation, long) - Static method in class com.hazelcast.spi.OperationAccessor
- 
Sets the callId for the Operation. 
- setCallTimeout(long) - Method in class com.hazelcast.spi.InvocationBuilder
-  
- setCallTimeout(Operation, long) - Static method in class com.hazelcast.spi.OperationAccessor
- 
Sets the call timeout in milliseconds for the Operation. 
- setCapacity(int) - Method in class com.hazelcast.config.RingbufferConfig
- 
Sets the capacity of the ringbuffer. 
- setCheckClassDefErrors(boolean) - Method in class com.hazelcast.config.SerializationConfig
- 
When enabled, serialization system will check for class definitions error at start and throw an Serialization
 Exception with error definition. 
- setCheckClassDefErrors(boolean) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- setCheckClassDefErrors(boolean) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
-  
- setChunkSize(int) - Method in class com.hazelcast.config.JobTrackerConfig
- 
Sets the number of emitted values before a chunk is send to the reducers. 
- setChunkSize(int) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
-  
- setClass(Class<? extends Serializer>) - Method in class com.hazelcast.config.SerializerConfig
- 
Sets the class of the serializer implementation. 
- setClassDefinitions(Set<ClassDefinition>) - Method in class com.hazelcast.config.SerializationConfig
-  
- setClassLoader(ClassLoader) - Method in class com.hazelcast.client.config.ClientConfig
- 
Sets the classLoader which is used by serialization and listener configuration 
- setClassLoader(ClassLoader) - Method in class com.hazelcast.config.Config
- 
Sets the class-loader to be used during de-serialization
 and as context class-loader of Hazelcast internal threads. 
- setClassLoader(ClassLoader) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- setClassLoader(ClassLoader) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
-  
- setClassName(String) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
- 
Sets class name of proxy factory 
- setClassName(String) - Method in class com.hazelcast.config.CachePartitionLostListenerConfigReadOnly
-  
- setClassName(String) - Method in class com.hazelcast.config.CredentialsFactoryConfig
-  
- setClassName(String) - Method in class com.hazelcast.config.EntryListenerConfigReadOnly
-  
- setClassName(String) - Method in class com.hazelcast.config.GlobalSerializerConfig
-  
- setClassName(String) - Method in class com.hazelcast.config.ItemListenerConfigReadOnly
-  
- setClassName(String) - Method in class com.hazelcast.config.ListenerConfig
- 
Sets the class name of the EventListener. 
- setClassName(String) - Method in class com.hazelcast.config.ListenerConfigReadOnly
-  
- setClassName(String) - Method in class com.hazelcast.config.LoginModuleConfig
-  
- setClassName(String) - Method in class com.hazelcast.config.MapPartitionLostListenerConfigReadOnly
-  
- setClassName(String) - Method in class com.hazelcast.config.MapStoreConfig
- 
Sets the name for the MapStore implementation class 
- setClassName(String) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
-  
- setClassName(String) - Method in class com.hazelcast.config.PermissionPolicyConfig
-  
- setClassName(String) - Method in class com.hazelcast.config.PredicateConfig
- 
Sets the class name of the Predicate. 
- setClassName(String) - Method in class com.hazelcast.config.QueueStoreConfig
-  
- setClassName(String) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
-  
- setClassName(String) - Method in class com.hazelcast.config.SecurityInterceptorConfig
-  
- setClassName(String) - Method in class com.hazelcast.config.SerializerConfig
- 
Sets the class name of the serializer implementation. 
- setClassName(String) - Method in class com.hazelcast.config.ServiceConfig
-  
- setClassName(String) - Method in class com.hazelcast.config.SocketInterceptorConfig
- 
- setClassVersion(int, int, int) - Method in interface com.hazelcast.internal.serialization.PortableContext
-  
- SetClearMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
- 
SetClearMessageTask 
- SetClearMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetClearMessageTask
-  
- setClientEngine(ClientEngineImpl) - Method in class com.hazelcast.client.impl.client.ClientRequest
-  
- setClientHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
-  
- setClientLoginModuleConfigs(List<LoginModuleConfig>) - Method in class com.hazelcast.config.SecurityConfig
-  
- setClientPermissionConfigs(Set<PermissionConfig>) - Method in class com.hazelcast.config.SecurityConfig
-  
- setClientPolicyConfig(PermissionPolicyConfig) - Method in class com.hazelcast.config.SecurityConfig
-  
- setClients(Collection<ClientEndPointDTO>) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- setClientThreadId(long) - Method in class com.hazelcast.transaction.client.BaseTransactionRequest
-  
- setClusterId(String) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- setClusterName(String) - Method in class com.hazelcast.monitor.TimedMemberState
-  
- setClusterStartTime(long) - Method in class com.hazelcast.cluster.impl.ClusterClockImpl
-  
- setClusterWideNew(boolean) - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- setCmdGet(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- setCmdSet(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- setCmdTouch(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- setCoalesce(boolean) - Method in class com.hazelcast.config.QueryCacheConfig
- 
Set trueto enable coalescing, otherwise setfalse.
 
- SetCommand - Class in com.hazelcast.internal.ascii.memcache
-  
- SetCommand(TextCommandConstants.TextCommandType, String, int, int, int, boolean) - Constructor for class com.hazelcast.internal.ascii.memcache.SetCommand
-  
- SetCommandParser - Class in com.hazelcast.internal.ascii.memcache
-  
- SetCommandParser(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.internal.ascii.memcache.SetCommandParser
-  
- SetCommandProcessor - Class in com.hazelcast.internal.ascii.memcache
-  
- SetCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.memcache.SetCommandProcessor
-  
- setCommittedHeap(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- setCommittedNativeMemory(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- setCommunicateStats(boolean) - Method in class com.hazelcast.config.JobTrackerConfig
- 
Set to true if statistics (for example, about processed entries)
 should be transmitted to the job emitter, false otherwise. 
- setCommunicateStats(boolean) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
-  
- SetCompareAndRemoveAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
- 
SetCompareAndRemoveAllMessageTask 
- SetCompareAndRemoveAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRemoveAllMessageTask
-  
- SetCompareAndRetainAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
- 
SetCompareAndRetainAllMessageTask 
- SetCompareAndRetainAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetCompareAndRetainAllMessageTask
-  
- setCompletionId(int) - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- setCompletionId(Integer) - Method in class com.hazelcast.cache.impl.client.AbstractCacheRequest
-  
- setCompletionId(Integer) - Method in class com.hazelcast.cache.impl.client.CacheEntryProcessorRequest
-  
- setCompletionId(Integer) - Method in class com.hazelcast.cache.impl.client.CacheGetAndRemoveRequest
-  
- setCompletionId(Integer) - Method in class com.hazelcast.cache.impl.client.CacheGetAndReplaceRequest
-  
- setCompletionId(Integer) - Method in class com.hazelcast.cache.impl.client.CachePutAllRequest
-  
- setCompletionId(Integer) - Method in class com.hazelcast.cache.impl.client.CachePutIfAbsentRequest
-  
- setCompletionId(Integer) - Method in class com.hazelcast.cache.impl.client.CachePutRequest
-  
- setCompletionId(Integer) - Method in class com.hazelcast.cache.impl.client.CacheRemoveRequest
-  
- setCompletionId(Integer) - Method in class com.hazelcast.cache.impl.client.CacheReplaceRequest
-  
- setCompletionId(Integer) - Method in interface com.hazelcast.cache.impl.client.CompletionAwareCacheRequest
- 
Sets the completion id of the cache request. 
- setCompletionId(int) - Method in class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
-  
- setCompletionId(int) - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
-  
- setCompletionId(int) - Method in interface com.hazelcast.cache.impl.operation.MutableOperation
-  
- setComputeService(ComputeService) - Method in class com.hazelcast.jclouds.ComputeServiceBuilder
- 
Injects already built ComputeService 
- setConcurrencyLevel(int) - Method in class com.hazelcast.config.ReplicatedMapConfig
- 
Deprecated.
new implementation doesn't use mutexes 
 
- setConfig(QueueConfig, NodeEngine, QueueService) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- SetConfig - Class in com.hazelcast.config
- 
Contains the configuration for an  ISet. 
- SetConfig() - Constructor for class com.hazelcast.config.SetConfig
-  
- SetConfig(String) - Constructor for class com.hazelcast.config.SetConfig
-  
- SetConfig(SetConfig) - Constructor for class com.hazelcast.config.SetConfig
-  
- setConfig(SerializationConfig) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- setConfig(SerializationConfig) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
-  
- setConfigClassLoader(ClassLoader) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-  
- setConfigLocation(String) - Method in class com.hazelcast.jca.ResourceAdapterImpl
- 
Deprecated. 
- setConfigObject(Object) - Method in class com.hazelcast.config.ServiceConfig
-  
- setConfigPatternMatcher(ConfigPatternMatcher) - Method in class com.hazelcast.client.config.ClientConfig
-  
- setConfigPatternMatcher(ConfigPatternMatcher) - Method in class com.hazelcast.config.Config
-  
- SetConfigReadOnly - Class in com.hazelcast.config
- 
Contains configuration for Set(read only) 
- SetConfigReadOnly(SetConfig) - Constructor for class com.hazelcast.config.SetConfigReadOnly
-  
- setConfigurationFile(File) - Method in class com.hazelcast.config.Config
-  
- setConfigurationLocation(String) - Method in class com.hazelcast.jca.ResourceAdapterImpl
- 
Called by the container 
- setConfigurationUrl(URL) - Method in class com.hazelcast.config.Config
-  
- setConn(Connection) - Method in class com.hazelcast.nio.Packet
- 
Sets the Connection this Packet is send with. 
- setConnected(boolean) - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
-  
- setConnection(Operation, Connection) - Static method in class com.hazelcast.spi.OperationAccessor
-  
- setConnectionAttemptLimit(int) - Method in class com.hazelcast.client.config.ClientConfig
- 
Deprecated. 
- setConnectionAttemptLimit(int) - Method in class com.hazelcast.client.config.ClientNetworkConfig
- 
- setConnectionAttemptPeriod(int) - Method in class com.hazelcast.client.config.ClientConfig
- 
Deprecated. 
- setConnectionAttemptPeriod(int) - Method in class com.hazelcast.client.config.ClientNetworkConfig
- 
Period for the next attempt to find a member to connect. 
- setConnectionManagerBean(ConnectionManagerDTO) - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
-  
- setConnectionTimeout(int) - Method in class com.hazelcast.client.config.ClientConfig
- 
Deprecated. 
- setConnectionTimeout(int) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-  
- setConnectionTimeoutSeconds(int) - Method in class com.hazelcast.config.AwsConfig
- 
Sets the connect timeout in seconds. 
- setConnectionTimeoutSeconds(int) - Method in class com.hazelcast.config.TcpIpConfig
- 
Sets the connection timeout. 
- setConnectionTracingDetail(boolean) - Method in class com.hazelcast.jca.ManagedConnectionFactoryImpl
- 
Setter for the RAR property 'connectionTracingDetails'. 
- setConnectionTracingEvents(String) - Method in class com.hazelcast.jca.ManagedConnectionFactoryImpl
- 
Setter for the property 'connectionTracingEvents'. 
- SetContainer - Class in com.hazelcast.collection.impl.set
-  
- SetContainer() - Constructor for class com.hazelcast.collection.impl.set.SetContainer
-  
- SetContainer(String, NodeEngine) - Constructor for class com.hazelcast.collection.impl.set.SetContainer
-  
- SetContainsAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
- 
SetContainsAllMessageTask 
- SetContainsAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetContainsAllMessageTask
-  
- SetContainsMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
- 
SetContainsMessageTask 
- SetContainsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetContainsMessageTask
-  
- setContentType(byte[]) - Method in class com.hazelcast.internal.ascii.rest.RestValue
-  
- setContext(ClientContext) - Method in class com.hazelcast.client.spi.ClientProxy
-  
- setContextClassLoader(ClassLoader) - Method in class com.hazelcast.util.executor.HazelcastManagedThread
-  
- setCorrelationId(long) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
- 
Sets the correlation id field. 
- setCost(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- setCount(int) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
-  
- setCount(String, int) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-  
- setCountDirect(int) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchContainer
-  
- setCountDirect(String, int) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-  
- SetCountOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
-  
- SetCountOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
-  
- SetCountOperation(String, int) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
-  
- SetCountRequest - Class in com.hazelcast.concurrent.countdownlatch.client
-  
- SetCountRequest() - Constructor for class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-  
- SetCountRequest(String, int) - Constructor for class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-  
- setCreationTime(long) - Method in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-  
- setCreationTime(long) - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheRecord
- 
Sets the creation time of this  Evictable in milliseconds. 
- setCreationTime(long) - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-  
- setCreationTime(long) - Method in interface com.hazelcast.cache.impl.record.CacheRecord
- 
Sets the creation time of this  Evictable in milliseconds. 
- setCreationTime(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- setCreationTime(long) - Method in interface com.hazelcast.map.impl.record.Record
-  
- setCreationTime(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
-  
- setCreationTime(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- setCreationTime(long) - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
-  
- setCreationTime(long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- setCreationTime(long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-  
- setCredentials(Credentials) - Method in class com.hazelcast.client.config.ClientConfig
- 
- setCredentials(Credentials) - Method in class com.hazelcast.client.config.ClientSecurityConfig
-  
- setCredentialsClassname(String) - Method in class com.hazelcast.client.config.ClientSecurityConfig
-  
- setCurrConnections(int) - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- setCurrentThread(Thread) - Method in class com.hazelcast.spi.impl.operationexecutor.OperationRunner
- 
Sets the thread that is running this OperationRunner instance. 
- setData(Data) - Method in class com.hazelcast.collection.impl.queue.QueueItem
-  
- setDataKey(Data) - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- setDataKey(Data) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- setDataLoadTimeoutSeconds(int) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
- 
Sets data load timeout for hot-restart process,
 all members in the cluster should complete restoring their local data
 before this timeout. 
- setDataNewValue(Data) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- setDataOffset(int) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
- 
Sets the dataOffset field. 
- setDataOldValue(Data) - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- setDataOldValue(Data) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- setDataSerializableFactories(Map<Integer, DataSerializableFactory>) - Method in class com.hazelcast.config.SerializationConfig
-  
- setDataSerializableFactoryClasses(Map<Integer, String>) - Method in class com.hazelcast.config.SerializationConfig
-  
- setDataValue(Data) - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- setDecrHits(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- setDecrMisses(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- setDelaySeconds(int) - Method in class com.hazelcast.config.QueryCacheConfig
- 
Sets the minimum number of delay seconds which an event waits in the buffer of node
 before sending to a QueryCache
 
- setDeleteHits(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- setDeleteMisses(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- setDirty(boolean) - Method in class com.hazelcast.web.LocalCacheEntry
- 
Sets dirty. 
- setDirtyEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- setDirtyEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
- 
Defines the Discovery Provider SPI configuration 
- setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.config.JoinConfig
- 
- setDiscoveryConfig(DiscoveryConfig) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-  
- setDiscoveryMode(DiscoveryMode) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-  
- setDiscoveryNode(DiscoveryNode) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-  
- setDiscoveryServiceProvider(DiscoveryServiceProvider) - Method in class com.hazelcast.config.DiscoveryConfig
-  
- setDiscoveryServiceProvider(DiscoveryServiceProvider) - Method in class com.hazelcast.config.DiscoveryConfigReadOnly
-  
- setDiscoveryStrategyConfigs(List<DiscoveryStrategyConfig>) - Method in class com.hazelcast.config.DiscoveryConfig
-  
- setDone() - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-  
- setDone() - Method in class com.hazelcast.util.executor.DelegatingFuture
-  
- setDoubleAttribute(String, double) - Method in class com.hazelcast.client.impl.MemberImpl
-  
- setDoubleAttribute(String, double) - Method in class com.hazelcast.config.MemberAttributeConfig
-  
- setDoubleAttribute(String, double) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-  
- setDoubleAttribute(String, double) - Method in interface com.hazelcast.core.Member
- 
Defines a key-value pair double attribute for this member available
 to other cluster members. 
- setDoubleAttribute(String, double) - Method in class com.hazelcast.instance.MemberImpl
-  
- setDurability(int) - Method in class com.hazelcast.transaction.TransactionOptions
- 
Sets the transaction durability. 
- setEmptyQueueTtl(int) - Method in class com.hazelcast.config.QueueConfig
- 
Sets the TTL (time to live) for emptying the Queue. 
- setEmptyQueueTtl(int) - Method in class com.hazelcast.config.QueueConfigReadOnly
-  
- setEnableCompression(boolean) - Method in class com.hazelcast.config.SerializationConfig
- 
Enables compression when default java serialization is used. 
- setEnableCompression(boolean) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- setEnableCompression(boolean) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
-  
- setEnabled(boolean) - Method in class com.hazelcast.config.AwsConfig
- 
Enables or disables the aws join mechanism. 
- setEnabled(boolean) - Method in class com.hazelcast.config.HotRestartConfig
- 
Sets whether hot restart is enabled on related data structure. 
- setEnabled(boolean) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
- 
Sets whether hot restart is enabled on this member. 
- setEnabled(boolean) - Method in class com.hazelcast.config.InterfacesConfig
-  
- setEnabled(boolean) - Method in class com.hazelcast.config.ManagementCenterConfig
- 
Set to true to enable management center, false to disable. 
- setEnabled(boolean) - Method in class com.hazelcast.config.MapStoreConfig
- 
Enables and disables this configuration 
- setEnabled(boolean) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
-  
- setEnabled(boolean) - Method in class com.hazelcast.config.MulticastConfig
- 
Enables or disables the multicast discovery mechanism 
- setEnabled(boolean) - Method in class com.hazelcast.config.NativeMemoryConfig
-  
- setEnabled(boolean) - Method in class com.hazelcast.config.PartitionGroupConfig
- 
Enables or disables this PartitionGroupConfig. 
- setEnabled(boolean) - Method in class com.hazelcast.config.QueueStoreConfig
-  
- setEnabled(boolean) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
-  
- setEnabled(boolean) - Method in class com.hazelcast.config.QuorumConfig
-  
- setEnabled(boolean) - Method in class com.hazelcast.config.SecurityConfig
-  
- setEnabled(boolean) - Method in class com.hazelcast.config.ServiceConfig
-  
- setEnabled(boolean) - Method in class com.hazelcast.config.SocketInterceptorConfig
- 
Enables and disables this configuration 
- setEnabled(boolean) - Method in class com.hazelcast.config.SSLConfig
- 
Enables and disables this configuration. 
- setEnabled(boolean) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-  
- setEnabled(boolean) - Method in class com.hazelcast.config.TcpIpConfig
- 
Enables or disables the Tcp/Ip join mechanism. 
- setEnableDefaults(boolean) - Method in class com.hazelcast.config.ServicesConfig
-  
- setEnableSharedObject(boolean) - Method in class com.hazelcast.config.SerializationConfig
- 
Enables shared object when default java serialization is used. 
- setEnableSharedObject(boolean) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- setEnableSharedObject(boolean) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
-  
- setEndpoint(String) - Method in class com.hazelcast.aws.AWSClient
-  
- setEndpoint(ClientEndpoint) - Method in class com.hazelcast.client.impl.client.ClientRequest
-  
- setEndPoint(Address) - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- setEndpoint(Address) - Method in class com.hazelcast.partition.PartitionRuntimeState
-  
- setEndpoint(String) - Method in class com.hazelcast.security.AbstractCredentials
-  
- setEndpoint(String) - Method in interface com.hazelcast.security.Credentials
- 
Sets IP address of endpoint. 
- setEndpoints(Set<String>) - Method in class com.hazelcast.config.PermissionConfig
-  
- setEndpoints(List<String>) - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- setEntryCount(long) - Method in class com.hazelcast.cache.impl.CacheEntryCountResolver
-  
- setEntryCounting(boolean) - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap
-  
- setEntryCounting(boolean) - Method in interface com.hazelcast.cache.impl.record.CacheRecordMap
- 
Sets the entry counting behaviour. 
- setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.MapConfig
-  
- setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.MultiMapConfig
- 
Sets the list of entry listeners (listens for when entries are added or removed) for this MultiMap. 
- setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-  
- setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.QueryCacheConfig
-  
- setEntryView(EntryView) - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
-  
- setError(Throwable) - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-  
- setError(Throwable) - Method in class com.hazelcast.util.executor.DelegatingFuture
-  
- setEventHandler(EventHandler) - Method in class com.hazelcast.client.spi.impl.ClientInvocation
-  
- setEventObject(ReplicationEventObject) - Method in class com.hazelcast.wan.WanReplicationEvent
- 
Sets the event object. 
- setEventServiceBean(EventServiceDTO) - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
-  
- setEventType(CacheEventType) - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- setEventType(int) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.CacheConfig
- 
- setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Sets the eviction configuration for this  ICache. 
- setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.NearCacheConfig
- 
The eviction policy. 
- setEvictionConfig(EvictionConfig) - Method in class com.hazelcast.config.QueryCacheConfig
- 
- setEvictionCriteriaNumber(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- setEvictionCriteriaNumber(long) - Method in interface com.hazelcast.map.impl.record.Record
-  
- setEvictionCriteriaNumber(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
-  
- setEvictionCriteriaNumber(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- setEvictionPercentage(int) - Method in class com.hazelcast.config.MapConfig
- 
When maximum size is reached, the specified percentage of the map will be evicted. 
- setEvictionPercentage(int) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.CacheEvictionConfig
- 
Deprecated. 
- setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.CacheEvictionConfigReadOnly
- 
Deprecated. 
- setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.EvictionConfig
-  
- setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.EvictionConfigReadOnly
-  
- setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.MapConfig
- 
Sets the evictionPolicy 
- setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setEvictionPolicy(String) - Method in class com.hazelcast.config.NearCacheConfig
- 
Valid values are:
 NONE (no extra eviction, time-to-live-seconds may still apply),
 LRU  (Least Recently Used),
 LFU  (Least Frequently Used). 
- setEvictionPolicy(String) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
-  
- setEvictor(Evictor) - Method in class com.hazelcast.map.impl.MapContainer
-  
- setExecutionCallback(ExecutionCallback<Object>) - Method in class com.hazelcast.spi.InvocationBuilder
- 
Sets the ExecutionCallback. 
- setExecutor(Executor) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
- 
Sets the Executor that is going to process the event. 
- setExecutor(Executor) - Method in class com.hazelcast.config.ReliableTopicConfig
- 
Sets the Executor that is going to process the event. 
- setExecutorConfigs(Map<String, ExecutorConfig>) - Method in class com.hazelcast.config.Config
-  
- setExecutorPoolSize(int) - Method in class com.hazelcast.client.config.ClientConfig
- 
Sets Client side Executor pool size. 
- setExpirationTime(long) - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- setExpirationTime(long) - Method in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-  
- setExpirationTime(long) - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-  
- setExpirationTime(long) - Method in interface com.hazelcast.internal.eviction.Expirable
- 
Sets the expiration time in milliseconds. 
- setExpirationTime(Record, long) - Static method in class com.hazelcast.map.impl.ExpirationTimeSetter
- 
Sets expiration time if statistics are enabled. 
- setExpirationTime(long) - Method in class com.hazelcast.map.impl.record.EmptyRecordStatistics
-  
- setExpirationTime(long) - Method in interface com.hazelcast.map.impl.record.RecordStatistics
-  
- setExpirationTime(long) - Method in class com.hazelcast.map.impl.record.RecordStatisticsImpl
-  
- setExpirationTime(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- setExpiryPolicyFactory(Factory<? extends ExpiryPolicy>) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setExpiryPolicyFactory(Factory<? extends ExpiryPolicy>) - Method in interface com.hazelcast.config.CacheConfiguration
- 
Set the Factoryfor theExpiryPolicy.
 
- setExpiryPolicyFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Sets the factory for this ExpiryPolicy.
 
- setExpiryPolicyFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- setExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Sets the factory configuration for this ExpiryPolicy.
 
- setExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- setExtractor(String) - Method in class com.hazelcast.config.MapAttributeConfig
- 
Sets the full class name of the extractor in a String format, e.g. 
- setExtractor(String) - Method in class com.hazelcast.config.MapAttributeConfigReadOnly
-  
- setFactoryClassName(String) - Method in class com.hazelcast.config.MapStoreConfig
- 
Sets the name for the MapStoreFactory implementation class 
- setFactoryClassName(String) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
-  
- setFactoryClassName(String) - Method in class com.hazelcast.config.QueueStoreConfig
-  
- setFactoryClassName(String) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
-  
- setFactoryClassName(String) - Method in class com.hazelcast.config.SSLConfig
- 
- setFactoryImpl(ClientProxyFactory) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
- 
Sets factory implementation of proxy factory 
- setFactoryImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfig
- 
Sets the map store factory implementation object. 
- setFactoryImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
-  
- setFactoryImplementation(QueueStoreFactory) - Method in class com.hazelcast.config.QueueStoreConfig
-  
- setFactoryImplementation(QueueStoreFactory) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
-  
- setFactoryImplementation(Object) - Method in class com.hazelcast.config.SSLConfig
- 
- setFailedConnection(boolean) - Method in class com.hazelcast.web.ClusteredSessionService
-  
- setFilter(String) - Method in class com.hazelcast.config.WanReplicationRefReadOnly
-  
- setFilters(List<String>) - Method in class com.hazelcast.config.WanReplicationRef
-  
- setFloatAttribute(String, float) - Method in class com.hazelcast.client.impl.MemberImpl
-  
- setFloatAttribute(String, float) - Method in class com.hazelcast.config.MemberAttributeConfig
-  
- setFloatAttribute(String, float) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-  
- setFloatAttribute(String, float) - Method in interface com.hazelcast.core.Member
- 
Defines a key-value pair float attribute for this member available
 to other cluster members. 
- setFloatAttribute(String, float) - Method in class com.hazelcast.instance.MemberImpl
-  
- setFrameLength(int) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
- 
Sets the frame length field. 
- setFreeNativeMemory(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- setFreePhysical(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- setFsync(boolean) - Method in class com.hazelcast.config.HotRestartConfig
- 
Sets whether disk write should be followed by an fsync()system call.
 
- setGcStats(LocalGCStats) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- SetGetAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
- 
SetGetAllMessageTask 
- SetGetAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetGetAllMessageTask
-  
- setGetHits(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- setGetMisses(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- setGlobalOrderingEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
- 
Enable global ordering (all nodes listening to the same topic
 get their messages in the same order), or disable it (nodes get
 the messages in the order that the messages are published). 
- setGlobalOrderingEnabled(boolean) - Method in class com.hazelcast.config.TopicConfigReadOnly
-  
- setGlobalSerializerConfig(GlobalSerializerConfig) - Method in class com.hazelcast.config.SerializationConfig
-  
- setGroupConfig(GroupConfig) - Method in class com.hazelcast.client.config.ClientConfig
- 
- setGroupConfig(GroupConfig) - Method in class com.hazelcast.config.Config
-  
- setGroupName(String) - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- setGroupPassword(String) - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- setGroupType(PartitionGroupConfig.MemberGroupType) - Method in class com.hazelcast.config.PartitionGroupConfig
- 
Sets the MemberGroupType. 
- setHasBackup(boolean) - Method in class com.hazelcast.map.impl.MapKeyLoader
-  
- setHasRunningCleanup(boolean) - Method in class com.hazelcast.map.impl.PartitionContainer
-  
- setHazelcast(HazelcastInstance) - Method in class com.hazelcast.client.console.ClientConsoleApp
-  
- setHazelcast(HazelcastInstance) - Method in class com.hazelcast.console.ConsoleApp
-  
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.config.EntryListenerConfig.MapListenerToEntryListenerAdapter
-  
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.console.Echo
-  
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.console.SimulateLoadTask
-  
- setHazelcastInstance(HazelcastInstance) - Method in interface com.hazelcast.core.HazelcastInstanceAware
- 
Gets the HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService. 
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.executor.impl.RunnableAdapter
-  
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.instance.MemberImpl
-  
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- setHazelcastInstance(HazelcastInstance) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
-  
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.jca.ResourceAdapterImpl
- 
Sets the underlying hazelcast instance
 Used only for testing purposes 
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
-  
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
-  
- setHazelcastSession(HazelcastHttpSession, String) - Method in class com.hazelcast.web.WebFilter.RequestWrapper
-  
- setHeader(int) - Method in class com.hazelcast.nio.Packet
-  
- setHeadSequence(long) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-  
- setHeapCost(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- setHeapCost(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- setHits(int) - Method in class com.hazelcast.map.impl.record.EmptyRecordStatistics
-  
- setHits(int) - Method in interface com.hazelcast.map.impl.record.RecordStatistics
-  
- setHits(int) - Method in class com.hazelcast.map.impl.record.RecordStatisticsImpl
-  
- setHits(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- setHits(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- setHits(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- setHits(long) - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-  
- setHits(long) - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
-  
- setHits(long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- setHits(long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-  
- setHostHeader(String) - Method in class com.hazelcast.config.AwsConfig
- 
Sets the host header; the address where the EC2 API can be found. 
- setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Sets the HotRestartConfigfor thisCacheSimpleConfig
 
- setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.MapConfig
- 
Sets the HotRestartConfigfor thisMapConfig
 
- setHotRestartConfig(HotRestartConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setHotRestartPersistenceConfig(HotRestartPersistenceConfig) - Method in class com.hazelcast.config.Config
- 
Sets hot restart configuration. 
- setIamRole(String) - Method in class com.hazelcast.config.AwsConfig
- 
Sets the tag value. 
- setId(int) - Method in class com.hazelcast.jca.ConnectionFactoryImpl
-  
- setId(int) - Method in class com.hazelcast.jca.ManagedConnectionFactoryImpl
-  
- setId(int) - Method in class com.hazelcast.jca.ResourceAdapterImpl
-  
- setId(long) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-  
- setImplementation(CachePartitionLostListener) - Method in class com.hazelcast.config.CachePartitionLostListenerConfig
-  
- setImplementation(EventListener) - Method in class com.hazelcast.config.CachePartitionLostListenerConfigReadOnly
-  
- setImplementation(CachePartitionLostListener) - Method in class com.hazelcast.config.CachePartitionLostListenerConfigReadOnly
-  
- setImplementation(ICredentialsFactory) - Method in class com.hazelcast.config.CredentialsFactoryConfig
-  
- setImplementation(EventListener) - Method in class com.hazelcast.config.EntryListenerConfig
-  
- setImplementation(EntryListener) - Method in class com.hazelcast.config.EntryListenerConfig
-  
- setImplementation(EntryListener) - Method in class com.hazelcast.config.EntryListenerConfigReadOnly
-  
- setImplementation(EventListener) - Method in class com.hazelcast.config.EntryListenerConfigReadOnly
-  
- setImplementation(Serializer) - Method in class com.hazelcast.config.GlobalSerializerConfig
-  
- setImplementation(ItemListener) - Method in class com.hazelcast.config.ItemListenerConfig
-  
- setImplementation(ItemListener) - Method in class com.hazelcast.config.ItemListenerConfigReadOnly
-  
- setImplementation(EventListener) - Method in class com.hazelcast.config.ItemListenerConfigReadOnly
-  
- setImplementation(EventListener) - Method in class com.hazelcast.config.ListenerConfig
- 
Sets the EventListener implementation. 
- setImplementation(EventListener) - Method in class com.hazelcast.config.ListenerConfigReadOnly
-  
- setImplementation(MapPartitionLostListener) - Method in class com.hazelcast.config.MapPartitionLostListenerConfig
-  
- setImplementation(EventListener) - Method in class com.hazelcast.config.MapPartitionLostListenerConfigReadOnly
-  
- setImplementation(MapPartitionLostListener) - Method in class com.hazelcast.config.MapPartitionLostListenerConfigReadOnly
-  
- setImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfig
- 
Sets the map store implementation object 
- setImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
-  
- setImplementation(IPermissionPolicy) - Method in class com.hazelcast.config.PermissionPolicyConfig
-  
- setImplementation(Predicate) - Method in class com.hazelcast.config.PredicateConfig
- 
Sets the Predicate implementation. 
- setImplementation(QuorumListener) - Method in class com.hazelcast.config.QuorumListenerConfig
-  
- setImplementation(SecurityInterceptor) - Method in class com.hazelcast.config.SecurityInterceptorConfig
-  
- setImplementation(Serializer) - Method in class com.hazelcast.config.SerializerConfig
- 
Sets the serializer implementation instance. 
- setImplementation(Object) - Method in class com.hazelcast.config.SocketInterceptorConfig
- 
- setIncludeValue(boolean) - Method in class com.hazelcast.config.EntryListenerConfig
-  
- setIncludeValue(boolean) - Method in class com.hazelcast.config.EntryListenerConfigReadOnly
-  
- setIncludeValue(boolean) - Method in class com.hazelcast.config.ItemListenerConfig
-  
- setIncludeValue(boolean) - Method in class com.hazelcast.config.ItemListenerConfigReadOnly
-  
- setIncludeValue(boolean) - Method in class com.hazelcast.config.QueryCacheConfig
- 
Set trueto enable value caching, otherwise setfalse.
 
- setIncrHits(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- setIncrMisses(long) - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- setIndexConfigs(List<MapIndexConfig>) - Method in class com.hazelcast.config.QueryCacheConfig
-  
- setInitialized() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-  
- setInitialLoadMode(MapStoreConfig.InitialLoadMode) - Method in class com.hazelcast.config.MapStoreConfig
- 
Sets the initial load mode
  
 LAZY: Default load mode where load is async
 EAGER: load mode where load is blocked till all partitions are loaded 
- setInitialLoadMode(MapStoreConfig.InitialLoadMode) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
-  
- setInitialOutputBufferSize(int) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- setInitialOutputBufferSize(int) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
-  
- setInitialPermits(int) - Method in class com.hazelcast.config.SemaphoreConfig
- 
Sets the initial number of permits. 
- setInitialPermits(int) - Method in class com.hazelcast.config.SemaphoreConfigReadOnly
-  
- setInitialState(Address[][], int) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheConfig
- 
Data type that will be used to store records in this  ICache. 
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Sets the InMemory Format for this  ICache. 
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.MapConfig
- 
Binary type that will be used for storing records. 
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.NearCacheConfig
- 
Sets the data type used to store entries. 
- setInMemoryFormat(String) - Method in class com.hazelcast.config.NearCacheConfig
-  
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
-  
- setInMemoryFormat(String) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
-  
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.QueryCacheConfig
- 
Sets memory format of values of entries in QueryCache.
 
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.ReplicatedMapConfig
- 
Data type used to store entries. 
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.RingbufferConfig
- 
Sets the InMemoryFormat. 
- setInsideAws(boolean) - Method in class com.hazelcast.client.config.ClientAwsConfig
- 
Set to true if client is inside aws environment
 Default value is false. 
- setInstanceName(String) - Method in class com.hazelcast.client.config.ClientConfig
-  
- setInstanceName(String) - Method in class com.hazelcast.config.Config
-  
- setInstanceNames(Set<String>) - Method in class com.hazelcast.monitor.TimedMemberState
-  
- setIntAttribute(String, int) - Method in class com.hazelcast.client.impl.MemberImpl
-  
- setIntAttribute(String, int) - Method in class com.hazelcast.config.MemberAttributeConfig
-  
- setIntAttribute(String, int) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-  
- setIntAttribute(String, int) - Method in interface com.hazelcast.core.Member
- 
Defines a key-value pair int attribute for this member available
 to other cluster members. 
- setIntAttribute(String, int) - Method in class com.hazelcast.instance.MemberImpl
-  
- setInterfaces(Collection<String>) - Method in class com.hazelcast.config.InterfacesConfig
- 
Adds a collection of interfaces. 
- setInterfaces(Collection<String>) - Method in class com.hazelcast.config.MemberGroupConfig
- 
Sets the interfaces that are part of a group. 
- setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.NetworkConfig
-  
- setInternal(long, TimeUnit, Data, Data) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- setInternal(long, TimeUnit, Data, Data) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- setInternal(Data, Data, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-  
- setInvalidateOnChange(boolean) - Method in class com.hazelcast.config.NearCacheConfig
- 
True to evict the cached entries if the entries are changed (updated or removed). 
- setInvalidateOnChange(boolean) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
-  
- setInvocationTime(Operation, long) - Static method in class com.hazelcast.spi.OperationAccessor
- 
Sets the invocation time for the Operation. 
- setIsAuthenticatedAsOwner() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- SetIsEmptyMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
- 
SetIsEmptyMessageTask 
- SetIsEmptyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetIsEmptyMessageTask
-  
- setIsOldValueAvailable(boolean) - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- setItemId(long) - Method in class com.hazelcast.collection.impl.queue.QueueItem
-  
- setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.CollectionConfig
- 
Sets the list of ItemListenerConfigs. 
- setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.ListConfigReadOnly
-  
- setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.QueueConfig
- 
Set the list of item listener configurations for this queue. 
- setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.QueueConfigReadOnly
-  
- setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.SetConfigReadOnly
-  
- setIterationCount(int) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-  
- setIterationType(IterationType) - Method in class com.hazelcast.query.PagingPredicate
-  
- setJobTrackerConfigs(Map<String, JobTrackerConfig>) - Method in class com.hazelcast.config.Config
-  
- setJoin(JoinConfig) - Method in class com.hazelcast.config.NetworkConfig
-  
- setJoined() - Method in class com.hazelcast.instance.Node
-  
- setKeepAlive(boolean) - Method in class com.hazelcast.client.config.SocketOptions
- 
Enable/disable SO_KEEPALIVE socket option. 
- setKey(byte[]) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-  
- setKey(Object) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- setKey(Data) - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- setKey(K) - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- setKey(Data) - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
-  
- setKey(Data) - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
-  
- setKey(K) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- setKeyType(String) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Sets the key type for this  ICache. 
- setKeyType(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- SetKeyValueSource<V> - Class in com.hazelcast.mapreduce.impl
- 
- SetKeyValueSource() - Constructor for class com.hazelcast.mapreduce.impl.SetKeyValueSource
-  
- SetKeyValueSource(String) - Constructor for class com.hazelcast.mapreduce.impl.SetKeyValueSource
-  
- setLastAccessTime(long) - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- setLastAccessTime(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
- 
Sets the cache last access time as atomic if the given time is bigger than it. 
- setLastAccessTime(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- setLastAccessTime(long) - Method in interface com.hazelcast.map.impl.record.Record
-  
- setLastAccessTime(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
-  
- setLastAccessTime(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- setLastAccessTime(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- setLastAccessTime(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- setLastAccessTime(long) - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
-  
- setLastAccessTime(long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- setLastAccessTime(long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-  
- setLastCleanupTime(long) - Method in class com.hazelcast.map.impl.PartitionContainer
-  
- setLastCleanupTimeCopy(long) - Method in class com.hazelcast.map.impl.PartitionContainer
-  
- setLastStoredTime(long) - Method in class com.hazelcast.map.impl.record.EmptyRecordStatistics
-  
- setLastStoredTime(long) - Method in interface com.hazelcast.map.impl.record.RecordStatistics
-  
- setLastStoredTime(long) - Method in class com.hazelcast.map.impl.record.RecordStatisticsImpl
-  
- setLastStoredTime(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- setLastUpdateTime(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
- 
Sets the cache last update time as atomic if the given time is bigger than it. 
- setLastUpdateTime(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- setLastUpdateTime(long) - Method in interface com.hazelcast.map.impl.record.Record
-  
- setLastUpdateTime(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
-  
- setLastUpdateTime(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- setLastUpdateTime(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- setLastUpdateTime(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- setLastUpdateTime(long) - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
-  
- setLastUpdateTime(long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- setLicenseKey(String) - Method in class com.hazelcast.client.config.ClientConfig
-  
- setLicenseKey(String) - Method in class com.hazelcast.config.Config
-  
- setLingerSeconds(int) - Method in class com.hazelcast.client.config.SocketOptions
- 
Enable/disable SO_LINGER with the specified linger time in seconds 
- setListConfigs(Map<String, ListConfig>) - Method in class com.hazelcast.config.Config
-  
- setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.client.config.ClientConfig
- 
- setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.Config
-  
- setListenerConfigs(List<QuorumListenerConfig>) - Method in class com.hazelcast.config.QuorumConfig
-  
- setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.ReplicatedMapConfig
-  
- setLiteMember(boolean) - Method in class com.hazelcast.config.Config
-  
- setLoadBalancer(LoadBalancer) - Method in class com.hazelcast.client.config.ClientConfig
- 
- setLoaded(boolean) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-  
- setLoaded(boolean) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- setLocal(boolean) - Method in class com.hazelcast.config.EntryListenerConfig
-  
- setLocal(boolean) - Method in class com.hazelcast.config.EntryListenerConfigReadOnly
-  
- setLocalMemoryStats(LocalMemoryStats) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- setLocalOnly() - Method in class com.hazelcast.client.impl.client.BaseClientAddListenerRequest
-  
- setLocalPublisherStatsMap(Map<String, LocalWanPublisherStats>) - Method in class com.hazelcast.monitor.impl.LocalWanStatsImpl
-  
- setLocalResult(boolean) - Method in class com.hazelcast.quorum.impl.QuorumImpl
-  
- setLocalUpdatePolicy(NearCacheConfig.LocalUpdatePolicy) - Method in class com.hazelcast.config.NearCacheConfig
-  
- setLockedEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- setLockedEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- setLogger(ILogger) - Method in class com.hazelcast.spi.discovery.integration.DiscoveryServiceSettings
-  
- setLoginContext(LoginContext) - Method in interface com.hazelcast.client.ClientEndpoint
-  
- setLoginContext(LoginContext) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- setLogWriter(PrintWriter) - Method in class com.hazelcast.jca.JcaBase
- 
Sets the container specific container LOGGER 
- setLongAttribute(String, long) - Method in class com.hazelcast.client.impl.MemberImpl
-  
- setLongAttribute(String, long) - Method in class com.hazelcast.config.MemberAttributeConfig
-  
- setLongAttribute(String, long) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-  
- setLongAttribute(String, long) - Method in interface com.hazelcast.core.Member
- 
Defines a key-value pair long attribute for this member available
 to other cluster members. 
- setLongAttribute(String, long) - Method in class com.hazelcast.instance.MemberImpl
-  
- setLoopbackModeEnabled(boolean) - Method in class com.hazelcast.config.MulticastConfig
- 
Enables or disables the loopback mode in the multicast discovery mechanism. 
- setMajorCount(long) - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-  
- setMajorTime(long) - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-  
- setManagedContext(ManagedContext) - Method in class com.hazelcast.client.config.ClientConfig
- 
- setManagedContext(ManagedContext) - Method in class com.hazelcast.config.Config
-  
- setManagedContext(ManagedContext) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- setManagedContext(ManagedContext) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
-  
- setManagementCenterConfig(ManagementCenterConfig) - Method in class com.hazelcast.config.Config
-  
- setManagementEnabled(CacheConfig, String, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- setManagementEnabled(CacheConfig, String, boolean) - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- setManagementEnabled(boolean) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setManagementEnabled(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
- 
Sets whether management is enabled on a cache. 
- setManagementEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Sets management to enabled or disabled for this  ICache. 
- setManagementEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- setManagerPrefix(String) - Method in class com.hazelcast.config.CacheConfig
- 
Sets the manager prefix of the  ICache. 
- setManagerPrefix(String) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setMapAttributeConfigs(List<MapAttributeConfig>) - Method in class com.hazelcast.config.MapConfig
-  
- setMapConfig(MapConfig) - Method in class com.hazelcast.map.impl.MapContainer
-  
- setMapConfigs(Map<String, MapConfig>) - Method in class com.hazelcast.config.Config
-  
- setMapContainer(MapContainer) - Method in class com.hazelcast.map.impl.operation.MapOperation
-  
- setMapIndexConfigs(List<MapIndexConfig>) - Method in class com.hazelcast.config.MapConfig
-  
- setMapIndexConfigs(List<MapIndexConfig>) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setMapName(String) - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
-  
- setMapName(String) - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
-  
- setMapName(String) - Method in class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-  
- setMapOperationProvider(MapOperationProvider) - Method in class com.hazelcast.map.impl.MapKeyLoader
-  
- setMapService(MapService) - Method in class com.hazelcast.map.impl.operation.MapOperation
-  
- setMapStoreConfig(MapStoreConfig) - Method in class com.hazelcast.config.MapConfig
- 
Sets the map store configuration 
- setMapStoreConfig(MapStoreConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setMaster(Boolean) - Method in class com.hazelcast.monitor.TimedMemberState
-  
- setMaster(Address) - Method in class com.hazelcast.partition.MigrationInfo
-  
- setMasterAddress(Address) - Method in class com.hazelcast.instance.Node
-  
- SetMasterOperation - Class in com.hazelcast.cluster.impl.operations
-  
- SetMasterOperation() - Constructor for class com.hazelcast.cluster.impl.operations.SetMasterOperation
-  
- SetMasterOperation(Address) - Constructor for class com.hazelcast.cluster.impl.operations.SetMasterOperation
-  
- setMasterTime(long) - Method in class com.hazelcast.cluster.impl.ClusterClockImpl
-  
- setMasterUuid(String) - Method in class com.hazelcast.partition.MigrationInfo
-  
- setMaxAge(long) - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- setMaxBatch(int) - Method in class com.hazelcast.map.impl.MapKeyLoader
-  
- setMaxHeap(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- setMaxIdleSeconds(int) - Method in class com.hazelcast.config.MapConfig
- 
Maximum number of seconds for each entry to stay idle in the map. 
- setMaxIdleSeconds(int) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setMaxIdleSeconds(int) - Method in class com.hazelcast.config.NearCacheConfig
- 
Maximum number of seconds each entry can stay in the near cache as untouched (not-read). 
- setMaxIdleSeconds(int) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
-  
- setMaximumSizePolicy(EvictionConfig.MaxSizePolicy) - Method in class com.hazelcast.config.CacheEvictionConfig
- 
Deprecated. 
- setMaximumSizePolicy(EvictionConfig.MaxSizePolicy) - Method in class com.hazelcast.config.CacheEvictionConfigReadOnly
- 
Deprecated. 
- setMaximumSizePolicy(EvictionConfig.MaxSizePolicy) - Method in class com.hazelcast.config.EvictionConfig
-  
- setMaximumSizePolicy(EvictionConfig.MaxSizePolicy) - Method in class com.hazelcast.config.EvictionConfigReadOnly
-  
- setMaxInactiveInterval(int) - Method in class com.hazelcast.web.HazelcastHttpSession
-  
- setMaxNativeMemory(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- setMaxSize(int) - Method in class com.hazelcast.config.CollectionConfig
- 
Sets the maximum size for the collection. 
- setMaxSize(int) - Method in class com.hazelcast.config.ListConfigReadOnly
-  
- setMaxSize(int) - Method in class com.hazelcast.config.NearCacheConfig
- 
Sets the maximum size of the near cache. 
- setMaxSize(int) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
-  
- setMaxSize(int) - Method in class com.hazelcast.config.QueueConfig
- 
Sets the maximum size of the Queue. 
- setMaxSize(int) - Method in class com.hazelcast.config.QueueConfigReadOnly
-  
- setMaxSize(int) - Method in class com.hazelcast.config.SetConfigReadOnly
-  
- setMaxSize(int) - Method in class com.hazelcast.map.impl.MapKeyLoader
-  
- setMaxSizeConfig(MaxSizeConfig) - Method in class com.hazelcast.config.MapConfig
-  
- setMaxSizeConfig(MaxSizeConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setMaxSizePolicy(CacheEvictionConfig.CacheMaxSizePolicy) - Method in class com.hazelcast.config.CacheEvictionConfig
- 
- setMaxSizePolicy(CacheEvictionConfig.CacheMaxSizePolicy) - Method in class com.hazelcast.config.CacheEvictionConfigReadOnly
- 
Deprecated. 
- setMaxSizePolicy(MaxSizeConfig.MaxSizePolicy) - Method in class com.hazelcast.config.MaxSizeConfig
- 
Ses the maximum size policy of the map. 
- setMaxSizePolicy(MaxSizeConfig.MaxSizePolicy) - Method in class com.hazelcast.config.MaxSizeConfigReadOnly
-  
- setMaxThreadSize(int) - Method in class com.hazelcast.config.JobTrackerConfig
- 
Sets the maximum thread pool size of this  JobTracker. 
- setMaxThreadSize(int) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
-  
- SetMBean - Class in com.hazelcast.jmx
- 
- SetMBean(ISet, ManagementService) - Constructor for class com.hazelcast.jmx.SetMBean
-  
- setMemberAttributeConfig(MemberAttributeConfig) - Method in class com.hazelcast.config.Config
-  
- setMemberCredentialsConfig(CredentialsFactoryConfig) - Method in class com.hazelcast.config.SecurityConfig
-  
- setMemberGroupConfigs(Collection<MemberGroupConfig>) - Method in class com.hazelcast.config.PartitionGroupConfig
- 
Adds a MemberGroupConfig. 
- setMemberList(List<String>) - Method in class com.hazelcast.monitor.TimedMemberState
-  
- setMemberLoginModuleConfigs(List<LoginModuleConfig>) - Method in class com.hazelcast.config.SecurityConfig
-  
- setMembers(List<String>) - Method in class com.hazelcast.config.TcpIpConfig
- 
Sets the well known members. 
- setMemberState(MemberStateImpl) - Method in class com.hazelcast.monitor.TimedMemberState
-  
- setMemberStateSafe(boolean) - Method in class com.hazelcast.monitor.impl.MemberPartitionStateImpl
-  
- setMemoryInfoAccessor(MemoryInfoAccessor) - Method in class com.hazelcast.map.impl.eviction.EvictionCheckerImpl
-  
- setMergePolicy(String) - Method in class com.hazelcast.config.CacheConfig
- 
- setMergePolicy(String) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setMergePolicy(String) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
- setMergePolicy(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- setMergePolicy(String) - Method in class com.hazelcast.config.MapConfig
- 
- setMergePolicy(String) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setMergePolicy(String) - Method in class com.hazelcast.config.ReplicatedMapConfig
- 
- setMergePolicy(String) - Method in class com.hazelcast.config.WanReplicationRef
-  
- setMergePolicy(String) - Method in class com.hazelcast.config.WanReplicationRefReadOnly
-  
- setMergePolicy(MapMergePolicy) - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
-  
- setMessageListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.TopicConfig
- 
Sets the list of message listeners (listens for when messages are added or removed) for this topic. 
- setMessageListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.TopicConfigReadOnly
-  
- setMessageType(int) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
- 
Sets the message type field. 
- setMetadataSpacePercentage(float) - Method in class com.hazelcast.config.NativeMemoryConfig
-  
- setMigrationQueueSize(long) - Method in class com.hazelcast.monitor.impl.MemberPartitionStateImpl
-  
- setMinAge(long) - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- setMinBlockSize(int) - Method in class com.hazelcast.config.NativeMemoryConfig
-  
- setMinEvictionCheckMillis(long) - Method in class com.hazelcast.config.MapConfig
- 
Sets the minimum time in milliseconds which should pass before asking if a partition of this map is evictable or not. 
- setMinEvictionCheckMillis(long) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setMinorCount(long) - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-  
- setMinorTime(long) - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-  
- setMisses(long) - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-  
- setMonitor(TcpIpConnectionMonitor) - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- setMulticastConfig(MulticastConfig) - Method in class com.hazelcast.config.JoinConfig
-  
- setMulticastGroup(String) - Method in class com.hazelcast.config.MulticastConfig
- 
Sets the multicast group. 
- setMulticastPort(int) - Method in class com.hazelcast.config.MulticastConfig
- 
Sets the multicast port. 
- setMulticastTimeoutSeconds(int) - Method in class com.hazelcast.config.MulticastConfig
- 
Specifies the time in seconds that a node should wait for a valid multicast response from another node running
 in the network before declaring itself as master node and creating its own cluster. 
- setMulticastTimeToLive(int) - Method in class com.hazelcast.config.MulticastConfig
- 
Sets the time to live for the multicast package; a value between 0..255. 
- setMultiMapConfigs(Map<String, MultiMapConfig>) - Method in class com.hazelcast.config.Config
-  
- setName(String) - Method in class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
-  
- setName(String) - Method in class com.hazelcast.config.CacheConfig
- 
- setName(String) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setName(String) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
- setName(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- setName(String) - Method in class com.hazelcast.config.CollectionConfig
- 
Sets the name of this collection. 
- setName(String) - Method in class com.hazelcast.config.ExecutorConfig
- 
Sets the name of the executor task. 
- setName(String) - Method in class com.hazelcast.config.ExecutorConfigReadOnly
-  
- setName(String) - Method in class com.hazelcast.config.GroupConfig
- 
Sets the group name of the group. 
- setName(String) - Method in class com.hazelcast.config.JobTrackerConfig
- 
- setName(String) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
-  
- setName(String) - Method in class com.hazelcast.config.ListConfigReadOnly
-  
- setName(String) - Method in class com.hazelcast.config.MapAttributeConfig
- 
Sets the name of the attribute extracted by the extractor. 
- setName(String) - Method in class com.hazelcast.config.MapAttributeConfigReadOnly
-  
- setName(String) - Method in class com.hazelcast.config.MapConfig
- 
Sets the name of the  IMap
- setName(String) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setName(String) - Method in class com.hazelcast.config.MultiMapConfig
- 
Sets the name of this MultiMap. 
- setName(String) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-  
- setName(String) - Method in class com.hazelcast.config.NearCacheConfig
- 
Sets the name of the near cache. 
- setName(String) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
-  
- setName(String) - Method in class com.hazelcast.config.PermissionConfig
-  
- setName(String) - Method in class com.hazelcast.config.QueryCacheConfig
- 
Sets the name of QueryCache.
 
- setName(String) - Method in class com.hazelcast.config.QueueConfig
- 
Set the name for this queue. 
- setName(String) - Method in class com.hazelcast.config.QueueConfigReadOnly
-  
- setName(String) - Method in class com.hazelcast.config.QuorumConfig
-  
- setName(String) - Method in class com.hazelcast.config.ReplicatedMapConfig
- 
- setName(String) - Method in class com.hazelcast.config.SemaphoreConfig
- 
Sets the name of the semaphore. 
- setName(String) - Method in class com.hazelcast.config.SemaphoreConfigReadOnly
-  
- setName(String) - Method in class com.hazelcast.config.ServiceConfig
-  
- setName(String) - Method in class com.hazelcast.config.SetConfigReadOnly
-  
- setName(String) - Method in class com.hazelcast.config.TopicConfig
- 
Sets the name of the topic. 
- setName(String) - Method in class com.hazelcast.config.TopicConfigReadOnly
-  
- setName(String) - Method in class com.hazelcast.config.WanReplicationConfig
-  
- setName(String) - Method in class com.hazelcast.config.WanReplicationRef
-  
- setName(String) - Method in class com.hazelcast.config.WanReplicationRefReadOnly
-  
- setNativeMemoryConfig(NativeMemoryConfig) - Method in class com.hazelcast.client.config.ClientConfig
-  
- setNativeMemoryConfig(NativeMemoryConfig) - Method in class com.hazelcast.config.Config
-  
- setNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.config.MapConfig
- 
Sets the near cache configuration 
- setNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setNearCacheConfigMap(Map<String, NearCacheConfig>) - Method in class com.hazelcast.client.config.ClientConfig
- 
- setNearCacheExecutor(NearCacheExecutor) - Method in class com.hazelcast.cache.impl.nearcache.NearCacheContext
-  
- setNearCacheManager(NearCacheManager) - Method in class com.hazelcast.cache.impl.nearcache.NearCacheContext
-  
- setNearCacheSizeEstimator(SizeEstimator) - Method in class com.hazelcast.map.impl.nearcache.NearCacheImpl
-  
- setNearCacheStats(NearCacheStats) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- setNetworkConfig(ClientNetworkConfig) - Method in class com.hazelcast.client.config.ClientConfig
- 
- setNetworkConfig(NetworkConfig) - Method in class com.hazelcast.config.Config
-  
- setNextRecordId(long) - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
-  
- setNode(Node) - Method in class com.hazelcast.spi.impl.BinaryOperationFactory
-  
- setNode(Node) - Method in interface com.hazelcast.spi.NodeAware
-  
- setNodeEngine(NodeEngine) - Method in class com.hazelcast.spi.Operation
-  
- setNodeFilter(NodeFilter) - Method in class com.hazelcast.config.DiscoveryConfig
-  
- setNodeFilter(NodeFilter) - Method in class com.hazelcast.config.DiscoveryConfigReadOnly
-  
- setNodeFilterClass(String) - Method in class com.hazelcast.config.DiscoveryConfig
-  
- setNodeFilterClass(String) - Method in class com.hazelcast.config.DiscoveryConfigReadOnly
-  
- setObject(Object) - Method in class com.hazelcast.multimap.impl.MultiMapRecord
-  
- setObjectName(Map<String, String>) - Method in class com.hazelcast.jmx.HazelcastMBean
-  
- setOldValueRequired(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
- 
If true, previously assigned values for the affected keys will be sent to this
 cache entry listener implementation. 
- setOldValueRequired(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
-  
- SetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-  
- SetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.SetOperation
-  
- SetOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.SetOperation
-  
- SetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-  
- SetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.SetOperation
-  
- SetOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.SetOperation
-  
- SetOperation - Class in com.hazelcast.map.impl.operation
-  
- SetOperation() - Constructor for class com.hazelcast.map.impl.operation.SetOperation
-  
- SetOperation(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.operation.SetOperation
-  
- setOperationResponseHandler(OperationResponseHandler) - Method in class com.hazelcast.spi.Operation
- 
Sets the OperationResponseHandler. 
- setOperationService(OperationService) - Method in class com.hazelcast.client.impl.client.ClientRequest
-  
- setOperationServiceBean(OperationServiceDTO) - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
-  
- setOperationStats(LocalOperationStats) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- setOptimizeQueries(boolean) - Method in class com.hazelcast.config.MapConfig
- 
- setOptimizeQueries(boolean) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setOrdered(boolean) - Method in class com.hazelcast.config.MapIndexConfig
- 
Configures the index to be ordered or not ordered. 
- setOrdered(boolean) - Method in class com.hazelcast.config.MapIndexConfigReadOnly
-  
- setOrderKey(int) - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- setOrigin(String) - Method in class com.hazelcast.cache.impl.CacheEventContext
-  
- setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.NetworkConfig
-  
- setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.NetworkConfig
-  
- setOutboundQueueSize(int) - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
-  
- setOutOfMemoryHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.client.HazelcastClient
- 
Sets OutOfMemoryHandler to be used when an OutOfMemoryError
 is caught by Hazelcast Client threads. 
- setOutOfMemoryHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.core.Hazelcast
- 
Sets OutOfMemoryHandler to be used when an OutOfMemoryError
 is caught by Hazelcast threads. 
- setOverrideJavaSerialization(boolean) - Method in class com.hazelcast.config.GlobalSerializerConfig
-  
- setOwnedEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- setOwnedEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- setOwnedEntryCount(long) - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-  
- setOwnedEntryMemoryCost(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-  
- setOwnedEntryMemoryCost(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-  
- setOwnedEntryMemoryCost(long) - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-  
- setOwnedItemCount(int) - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-  
- setOwnerConnection(boolean) - Method in class com.hazelcast.client.impl.client.AuthenticationRequest
-  
- setOwnerUuid(String) - Method in interface com.hazelcast.map.impl.tx.MapTxnOperation
-  
- setOwnerUuid(String) - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-  
- setOwnerUuid(String) - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-  
- setOwnerUuid(String) - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-  
- setPage(int) - Method in class com.hazelcast.query.PagingPredicate
-  
- setPageSize(int) - Method in class com.hazelcast.config.NativeMemoryConfig
-  
- setPartitionCount(int) - Method in class com.hazelcast.internal.management.dto.PartitionServiceBeanDTO
-  
- setPartitionGroupConfig(PartitionGroupConfig) - Method in class com.hazelcast.config.Config
-  
- setPartitionId(int) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
- 
Sets the partition id field. 
- setPartitionId(int) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- setPartitionId(int) - Method in class com.hazelcast.mapreduce.impl.MapKeyValueSource
-  
- setPartitionId(int) - Method in class com.hazelcast.mapreduce.impl.MultiMapKeyValueSource
-  
- setPartitionId(int) - Method in class com.hazelcast.mapreduce.impl.task.DefaultContext
-  
- setPartitionId(int) - Method in interface com.hazelcast.mapreduce.PartitionIdAware
- 
Sets the partition id to the implementing instance it is executed against 
- setPartitionId(int) - Method in class com.hazelcast.spi.Operation
- 
Sets the partition id. 
- setPartitionIds(Collection<Integer>) - Method in class com.hazelcast.map.impl.query.QueryResult
-  
- setPartitioningStrategy(PartitioningStrategy) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- setPartitioningStrategy(PartitioningStrategy) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
-  
- setPartitioningStrategyClass(String) - Method in class com.hazelcast.config.PartitioningStrategyConfig
-  
- setPartitioningStrategyClass(String) - Method in class com.hazelcast.config.PartitioningStrategyConfigReadOnly
-  
- setPartitioningStrategyConfig(PartitioningStrategyConfig) - Method in class com.hazelcast.config.MapConfig
-  
- setPartitioningStrategyConfig(PartitioningStrategyConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setPartitionLostListenerConfigs(List<CachePartitionLostListenerConfig>) - Method in class com.hazelcast.config.CacheConfig
- 
Sets the WAN target replication reference. 
- setPartitionLostListenerConfigs(List<CachePartitionLostListenerConfig>) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setPartitionLostListenerConfigs(List<CachePartitionLostListenerConfig>) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Sets the PartitionLostListenerConfigs. 
- setPartitionLostListenerConfigs(List<CachePartitionLostListenerConfig>) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- setPartitionLostListenerConfigs(List<MapPartitionLostListenerConfig>) - Method in class com.hazelcast.config.MapConfig
-  
- setPartitionReplicaVersions(int, long[], int) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- setPartitionReplicaVersions(int, long[], int) - Method in interface com.hazelcast.partition.InternalPartitionService
-  
- setPartitionServiceBean(PartitionServiceBeanDTO) - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
-  
- setPartitionStrategy(PartitioningStrategy) - Method in class com.hazelcast.config.PartitioningStrategyConfig
-  
- setPartitionStrategy(PartitioningStrategy) - Method in class com.hazelcast.config.PartitioningStrategyConfigReadOnly
-  
- setPassword(String) - Method in class com.hazelcast.config.GroupConfig
- 
Sets the password for the group. 
- setPassword(String) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-  
- setPassword(String) - Method in class com.hazelcast.security.UsernamePasswordCredentials
- 
Sets the password. 
- setPaused(boolean) - Method in class com.hazelcast.monitor.impl.LocalWanPublisherStatsImpl
-  
- SetPermission - Class in com.hazelcast.security.permission
-  
- SetPermission(String, String...) - Constructor for class com.hazelcast.security.permission.SetPermission
-  
- setPollOperation(boolean) - Method in class com.hazelcast.collection.impl.txnqueue.TxQueueItem
-  
- setPoolSize(int) - Method in class com.hazelcast.config.ExecutorConfig
- 
Sets the number of executor threads per member for the executor. 
- setPoolSize(int) - Method in class com.hazelcast.config.ExecutorConfigReadOnly
-  
- setPopulate(boolean) - Method in class com.hazelcast.config.QueryCacheConfig
- 
Set trueto enable initial population, otherwise setfalse.
 
- setPort(int) - Method in class com.hazelcast.config.NetworkConfig
- 
Sets the port the Hazelcast member will try to bind on. 
- setPortableFactories(Map<Integer, PortableFactory>) - Method in class com.hazelcast.config.SerializationConfig
-  
- setPortableFactoryClasses(Map<Integer, String>) - Method in class com.hazelcast.config.SerializationConfig
-  
- setPortableVersion(int) - Method in class com.hazelcast.config.SerializationConfig
-  
- setPortableVersion(int) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- setPortableVersion(int) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
-  
- setPortAutoIncrement(boolean) - Method in class com.hazelcast.config.NetworkConfig
- 
Sets if a Hazelcast member is allowed to find a free port by incrementing the port number when it encounters
 an occupied port. 
- setPortCount(int) - Method in class com.hazelcast.config.NetworkConfig
- 
The maximum number of ports allowed to use. 
- setPredicateConfig(PredicateConfig) - Method in class com.hazelcast.config.QueryCacheConfig
- 
Sets the predicate of QueryCache.
 
- setPrincipal(ClientPrincipal) - Method in class com.hazelcast.client.spi.impl.ClusterListenerSupport
-  
- setPrincipal(String) - Method in class com.hazelcast.config.PermissionConfig
-  
- setPrincipal(String) - Method in class com.hazelcast.security.AbstractCredentials
-  
- setProperties(Properties) - Method in class com.hazelcast.client.config.ClientConfig
- 
sets all properties 
- setProperties(Properties) - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
-  
- setProperties(Properties) - Method in class com.hazelcast.config.Config
-  
- setProperties(Properties) - Method in class com.hazelcast.config.CredentialsFactoryConfig
-  
- setProperties(Properties) - Method in class com.hazelcast.config.LoginModuleConfig
-  
- setProperties(Properties) - Method in class com.hazelcast.config.MapStoreConfig
- 
Sets the properties 
- setProperties(Properties) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
-  
- setProperties(Properties) - Method in class com.hazelcast.config.PermissionPolicyConfig
-  
- setProperties(Properties) - Method in class com.hazelcast.config.QueueStoreConfig
-  
- setProperties(Properties) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
-  
- setProperties(Properties) - Method in class com.hazelcast.config.ServiceConfig
-  
- setProperties(Properties) - Method in class com.hazelcast.config.SocketInterceptorConfig
- 
Sets the properties. 
- setProperties(Properties) - Method in class com.hazelcast.config.SSLConfig
- 
Sets the properties. 
- setProperties(Properties) - Method in class com.hazelcast.config.XmlConfigBuilder
- 
Sets the used properties. 
- setProperty(String, String) - Method in class com.hazelcast.client.config.ClientConfig
- 
Sets the value of a named property. 
- setProperty(HazelcastProperty, String) - Method in class com.hazelcast.client.config.ClientConfig
- 
- setProperty(String, String) - Method in class com.hazelcast.config.Config
- 
Sets the value of a named property. 
- setProperty(HazelcastProperty, String) - Method in class com.hazelcast.config.Config
- 
- setProperty(String, String) - Method in class com.hazelcast.config.MapStoreConfig
-  
- setProperty(String, String) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
-  
- setProperty(String, String) - Method in class com.hazelcast.config.QueueStoreConfig
-  
- setProperty(String, String) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
-  
- setProperty(String, String) - Method in class com.hazelcast.config.SocketInterceptorConfig
- 
Sets a property. 
- setProperty(String, String) - Method in class com.hazelcast.config.SSLConfig
- 
Sets a property. 
- setProtocol(String) - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingSocketWriter
-  
- setProtocol(String) - Method in interface com.hazelcast.nio.tcp.SocketWriter
- 
Sets the protocol this SocketWriter should use. 
- setProtocol(String) - Method in class com.hazelcast.nio.tcp.spinning.SpinningSocketWriter
-  
- setProxyFactoryConfigs(List<ProxyFactoryConfig>) - Method in class com.hazelcast.client.config.ClientConfig
- 
- SetProxyImpl<E> - Class in com.hazelcast.collection.impl.set
-  
- SetProxyImpl(String, NodeEngine, SetService) - Constructor for class com.hazelcast.collection.impl.set.SetProxyImpl
-  
- setProxyServiceBean(ProxyServiceDTO) - Method in class com.hazelcast.internal.management.dto.MXBeansDTO
-  
- setPublicAddress(String) - Method in class com.hazelcast.config.NetworkConfig
- 
Overrides the public address of a member. 
- setQueryCacheConfigs(Map<String, Map<String, QueryCacheConfig>>) - Method in class com.hazelcast.client.config.ClientConfig
-  
- setQueryCacheConfigs(List<QueryCacheConfig>) - Method in class com.hazelcast.config.MapConfig
- 
Sets QueryCacheConfiginstances to thisMapConfig
 
- setQueueCapacity(int) - Method in class com.hazelcast.config.ExecutorConfig
- 
Sets the queue capacity of the executor task. 
- setQueueCapacity(int) - Method in class com.hazelcast.config.ExecutorConfigReadOnly
-  
- setQueueCapacity(int) - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- setQueueConfigs(Map<String, QueueConfig>) - Method in class com.hazelcast.config.Config
-  
- setQueueFullBehavior(WANQueueFullBehavior) - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- setQueueSize(int) - Method in class com.hazelcast.config.JobTrackerConfig
- 
Sets the maximum size of the queue; the maximum number of tasks that can wait to be processed. 
- setQueueSize(int) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
-  
- setQueueStoreConfig(QueueStoreConfig) - Method in class com.hazelcast.config.QueueConfig
- 
Set the QueueStore (load and store queue items from/to a database) configuration. 
- setQueueStoreConfig(QueueStoreConfig) - Method in class com.hazelcast.config.QueueConfigReadOnly
-  
- setQuorumConfigs(Map<String, QuorumConfig>) - Method in class com.hazelcast.config.Config
-  
- setQuorumFunctionClassName(String) - Method in class com.hazelcast.config.QuorumConfig
-  
- setQuorumFunctionImplementation(QuorumFunction) - Method in class com.hazelcast.config.QuorumConfig
-  
- setQuorumName(String) - Method in class com.hazelcast.config.CacheConfig
- 
Associates this cache configuration to a quorum. 
- setQuorumName(String) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setQuorumName(String) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Associates this cache configuration to a quorum. 
- setQuorumName(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- setQuorumName(String) - Method in class com.hazelcast.config.MapConfig
-  
- setReadBackupData(boolean) - Method in class com.hazelcast.config.MapConfig
- 
Sets read-backup-data (reading local backup entires) for this map. 
- setReadBackupData(boolean) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setReadBatchSize(int) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
- 
Sets the read batch size. 
- setReadBatchSize(int) - Method in class com.hazelcast.config.ReliableTopicConfig
- 
Sets the read batch size. 
- setReadThrough(boolean) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setReadThrough(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
- 
Set if read-through caching should be used. 
- setReadThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Enables or disables read-through: a read loads the entry from the data store if it is not already in the cache. 
- setReadThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- setReceiveBufferSize(int) - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- setRecordId(long) - Method in class com.hazelcast.multimap.impl.MultiMapRecord
-  
- setRedoOperation(boolean) - Method in class com.hazelcast.client.config.ClientConfig
- 
Deprecated. 
- setRedoOperation(boolean) - Method in class com.hazelcast.client.config.ClientNetworkConfig
- 
If true, client will redo the operations that were executing on the server and client lost the connection. 
- setReference(Reference) - Method in class com.hazelcast.jca.ConnectionFactoryImpl
-  
- setReferenceCallId(long) - Method in class com.hazelcast.concurrent.lock.operations.BaseLockOperation
-  
- setRegion(String) - Method in class com.hazelcast.config.AwsConfig
- 
Sets the region where the EC2 instances running the Hazelcast members will be running. 
- setRegistrationId(String) - Method in class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
-  
- setReload(boolean) - Method in class com.hazelcast.web.LocalCacheEntry
- 
Sets reload. 
- setRemoteEndpoint(Address) - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- setRemoved(boolean) - Method in class com.hazelcast.web.LocalCacheEntry
- 
Sets removed. 
- SetRemoveListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
- 
SetRemoveListenerMessageTask 
- SetRemoveListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetRemoveListenerMessageTask
-  
- SetRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
- 
SetRemoveMessageTask 
- SetRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetRemoveMessageTask
-  
- setRemoveOperation(boolean) - Method in class com.hazelcast.collection.impl.collection.TxCollectionItem
-  
- setRemoveTime(long) - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
-  
- setReplicaIndex(int) - Method in class com.hazelcast.spi.InvocationBuilder
- 
Sets the replicaIndex. 
- setReplicaIndex(int) - Method in class com.hazelcast.spi.Operation
-  
- setReplicatedMapConfigs(Map<String, ReplicatedMapConfig>) - Method in class com.hazelcast.config.Config
-  
- setReplicationDelayMillis(long) - Method in class com.hazelcast.config.ReplicatedMapConfig
- 
Deprecated.
since new implementation will route puts to the partition owner nodes,
 caching won't help replication speed because most of the time subsequent puts will end up in different nodes. 
 
- setReplicationImpl(String) - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- setReplicationImplObject(Object) - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- SetReplicationOperation - Class in com.hazelcast.collection.impl.set.operations
-  
- SetReplicationOperation() - Constructor for class com.hazelcast.collection.impl.set.operations.SetReplicationOperation
-  
- SetReplicationOperation(Map<String, CollectionContainer>, int, int) - Constructor for class com.hazelcast.collection.impl.set.operations.SetReplicationOperation
-  
- setReplicatorExecutorService(ScheduledExecutorService) - Method in class com.hazelcast.config.ReplicatedMapConfig
- 
Deprecated.
new implementation doesn't use executor service for replication. 
 
- setRepublishingEnabled(boolean) - Method in class com.hazelcast.config.WanReplicationRef
-  
- setRepublishingEnabled(boolean) - Method in class com.hazelcast.config.WanReplicationRefReadOnly
-  
- SetRequest - Class in com.hazelcast.concurrent.atomiclong.client
-  
- SetRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.SetRequest
-  
- SetRequest(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.client.SetRequest
-  
- SetRequest - Class in com.hazelcast.concurrent.atomicreference.client
-  
- SetRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.SetRequest
-  
- SetRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.SetRequest
-  
- setRequiredMember(String) - Method in class com.hazelcast.config.TcpIpConfig
- 
Sets the required member. 
- setResourceAdapter(ResourceAdapter) - Method in class com.hazelcast.jca.ManagedConnectionFactoryImpl
-  
- setResponse(byte[]) - Method in class com.hazelcast.internal.ascii.memcache.DeleteCommand
-  
- setResponse(byte[]) - Method in class com.hazelcast.internal.ascii.memcache.IncrementCommand
-  
- setResponse(byte[]) - Method in class com.hazelcast.internal.ascii.memcache.SetCommand
-  
- setResponse(byte[]) - Method in class com.hazelcast.internal.ascii.memcache.SimpleCommand
-  
- setResponse(Stats) - Method in class com.hazelcast.internal.ascii.memcache.StatsCommand
-  
- setResponse(byte[]) - Method in class com.hazelcast.internal.ascii.memcache.TouchCommand
-  
- setResponse(byte[]) - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
-  
- setResponse(byte[], byte[]) - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
- 
HTTP/1.0 200 OK
 Date: Fri, 31 Dec 1999 23:59:59 GMT
 Content-TextCommandType: text/html
 Content-Length: 1354 
- setResponseHandler(ResponseHandler) - Method in class com.hazelcast.spi.Operation
- 
Deprecated. 
- setResponseTimeoutMillis(long) - Method in class com.hazelcast.config.WanTargetClusterConfig
-  
- setResult(Object) - Method in class com.hazelcast.mapreduce.impl.task.TrackableJobFuture
-  
- setResult(Object) - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-  
- setResultDeserialized(boolean) - Method in class com.hazelcast.spi.InvocationBuilder
- 
Sets the automatic deserialized option for the result. 
- setRetryable(boolean) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
-  
- setRetryCount(int) - Method in class com.hazelcast.config.JobTrackerConfig
- 
retry count is currently not used but reserved for later use where the framework will
 automatically try to restart / retry operations from a available savepoint. 
- setRetryCount(int) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
-  
- setReuseAddress(boolean) - Method in class com.hazelcast.client.config.SocketOptions
- 
Enable/disable the SO_REUSEADDR socket option. 
- setReuseAddress(boolean) - Method in class com.hazelcast.config.NetworkConfig
- 
Sets the reuse address. 
- setRunnable(Runnable) - Method in class com.hazelcast.executor.impl.RunnableAdapter
-  
- setRuntimeProps(Map<String, Long>) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-  
- setSalt(String) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-  
- setScopeId(String) - Method in class com.hazelcast.nio.Address
-  
- setScriptEngineManager(ScriptEngineManager) - Static method in class com.hazelcast.internal.management.ScriptEngineManagerContext
-  
- setSecretKey(String) - Method in class com.hazelcast.config.AwsConfig
- 
Sets the secret key to access AWS. 
- setSecurityConfig(ClientSecurityConfig) - Method in class com.hazelcast.client.config.ClientConfig
- 
- setSecurityConfig(SecurityConfig) - Method in class com.hazelcast.config.Config
-  
- setSecurityGroupName(String) - Method in class com.hazelcast.config.AwsConfig
- 
Sets the security group name. 
- setSecurityInterceptorConfigs(List<SecurityInterceptorConfig>) - Method in class com.hazelcast.config.SecurityConfig
-  
- setSelectorMode(SelectorMode) - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingIOThreadingModel
-  
- setSemaphoreConfigs(Map<String, SemaphoreConfig>) - Method in class com.hazelcast.config.Config
-  
- setSendBufferSize(int) - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- setSendConnection(ClientConnection) - Method in class com.hazelcast.client.spi.impl.ClientInvocation
-  
- setSequence(long) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- setSequence(long) - Method in interface com.hazelcast.map.impl.querycache.event.sequence.Sequenced
- 
Sets sequence. 
- setSequence(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- setSequence(long) - Method in interface com.hazelcast.map.impl.record.Record
- 
Only used for Hot Restart, HDRecord 
- setSerializationConfig(SerializationConfig) - Method in class com.hazelcast.client.config.ClientConfig
- 
- setSerializationConfig(SerializationConfig) - Method in class com.hazelcast.config.Config
-  
- setSerializationService(SerializationService) - Method in class com.hazelcast.cache.impl.nearcache.NearCacheContext
-  
- setSerializationService(SerializationService) - Method in class com.hazelcast.client.impl.client.ClientRequest
-  
- setSerializationService(SerializationService) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- setSerializationService(SerializationService) - Method in interface com.hazelcast.map.impl.querycache.event.QueryCacheEventData
-  
- setSerializationService(SerializationService) - Method in class com.hazelcast.ringbuffer.impl.client.PortableReadResultSet
-  
- setSerializerConfigs(Collection<SerializerConfig>) - Method in class com.hazelcast.config.SerializationConfig
-  
- setServerHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
-  
- setService(String) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
-  
- setService(Object) - Method in class com.hazelcast.client.impl.client.ClientRequest
-  
- SetService - Class in com.hazelcast.collection.impl.set
-  
- SetService(NodeEngine) - Constructor for class com.hazelcast.collection.impl.set.SetService
-  
- setService(MapService) - Method in interface com.hazelcast.map.impl.MapServiceContext
-  
- setService(Object) - Method in class com.hazelcast.spi.Operation
-  
- setServiceConfigs(Collection<ServiceConfig>) - Method in class com.hazelcast.config.ServicesConfig
-  
- setServiceImpl(Object) - Method in class com.hazelcast.config.ServiceConfig
-  
- setServiceName(String) - Method in class com.hazelcast.collection.impl.collection.client.CollectionAddListenerRequest
-  
- setServiceName(String) - Method in class com.hazelcast.collection.impl.collection.client.CollectionRequest
-  
- setServiceName(String) - Method in class com.hazelcast.spi.Operation
-  
- setServiceName(String) - Method in class com.hazelcast.wan.WanReplicationEvent
- 
Sets the service name for this event object. 
- setServicesConfig(ServicesConfig) - Method in class com.hazelcast.config.Config
-  
- setSetConfigs(Map<String, SetConfig>) - Method in class com.hazelcast.config.Config
-  
- setShortAttribute(String, short) - Method in class com.hazelcast.client.impl.MemberImpl
-  
- setShortAttribute(String, short) - Method in class com.hazelcast.config.MemberAttributeConfig
-  
- setShortAttribute(String, short) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-  
- setShortAttribute(String, short) - Method in interface com.hazelcast.core.Member
- 
Defines a key-value pair short attribute for this member available
 to other cluster members. 
- setShortAttribute(String, short) - Method in class com.hazelcast.instance.MemberImpl
-  
- setSize(int) - Method in class com.hazelcast.config.CacheEvictionConfig
- 
Deprecated. 
- setSize(int) - Method in class com.hazelcast.config.CacheEvictionConfigReadOnly
- 
Deprecated. 
- setSize(int) - Method in class com.hazelcast.config.EvictionConfig
-  
- setSize(int) - Method in class com.hazelcast.config.EvictionConfigReadOnly
-  
- setSize(int) - Method in class com.hazelcast.config.MaxSizeConfig
- 
Sets the maximum size of the map. 
- setSize(int) - Method in class com.hazelcast.config.MaxSizeConfigReadOnly
-  
- setSize(MemorySize) - Method in class com.hazelcast.config.NativeMemoryConfig
-  
- setSize(int) - Method in class com.hazelcast.config.QuorumConfig
-  
- setSizeEstimator(SizeEstimator) - Method in interface com.hazelcast.map.impl.recordstore.Storage
-  
- SetSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.set
- 
SetSizeMessageTask 
- SetSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.set.SetSizeMessageTask
-  
- setSmartRouting(boolean) - Method in class com.hazelcast.client.config.ClientConfig
- 
Deprecated. 
- setSmartRouting(boolean) - Method in class com.hazelcast.client.config.ClientNetworkConfig
- 
If true, client will route the key based operations to owner of the key at the best effort. 
- setSnapshotEnabled(boolean) - Method in class com.hazelcast.config.WanReplicationConfig
-  
- setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.client.config.ClientConfig
- 
Deprecated. 
- setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-  
- setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.NetworkConfig
- 
- setSocketOptions(SocketOptions) - Method in class com.hazelcast.client.config.ClientConfig
- 
Deprecated. 
- setSocketOptions(SocketOptions) - Method in class com.hazelcast.client.config.ClientNetworkConfig
-  
- setSql(String) - Method in class com.hazelcast.config.PredicateConfig
- 
Sets sql string for this config. 
- setSSLConfig(SSLConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
- 
- setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.NetworkConfig
- 
- setStarted() - Method in class com.hazelcast.client.impl.LifecycleServiceImpl
-  
- setStatistics(RecordStatistics) - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- setStatistics(RecordStatistics) - Method in interface com.hazelcast.map.impl.record.Record
-  
- setStatistics(RecordStatistics) - Method in class com.hazelcast.map.impl.record.RecordInfo
-  
- setStatisticsEnabled(CacheConfig, String, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- setStatisticsEnabled(CacheConfig, String, boolean) - Method in interface com.hazelcast.cache.impl.ICacheService
-  
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setStatisticsEnabled(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
- 
Sets whether statistics gathering is enabled on a cache. 
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Sets statistics to enabled or disabled for this  ICache. 
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CollectionConfig
- 
Sets collection statistics to enabled or disabled. 
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ExecutorConfig
- 
Enables or disables statistics gathering on the executor task. 
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ExecutorConfigReadOnly
-  
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ListConfigReadOnly
-  
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MapConfig
- 
Sets statistics to enabled or disabled for this map. 
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MultiMapConfig
- 
Enables or disables statistics for this MultiMap. 
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-  
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.QueueConfig
- 
Enables or disables statistics for this queue. 
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.QueueConfigReadOnly
-  
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ReliableTopicConfig
- 
Enables or disables statistics for this reliable topic.. 
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ReplicatedMapConfig
- 
Sets statistics to enabled or disabled for this replicated map. 
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.SetConfigReadOnly
-  
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
- 
Enables or disables statistics for this topic. 
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.TopicConfigReadOnly
-  
- setStats(LocalQueueStatsImpl) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- setStoreByValue(boolean) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setStoreByValue(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
- 
Set if a configured cache should use store-by-value or store-by-reference
 semantics. 
- setStoreImplementation(QueueStore) - Method in class com.hazelcast.config.QueueStoreConfig
-  
- setStoreImplementation(QueueStore) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
-  
- setStoreTime(long) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntry
-  
- setStringAttribute(String, String) - Method in class com.hazelcast.client.impl.MemberImpl
-  
- setStringAttribute(String, String) - Method in class com.hazelcast.config.MemberAttributeConfig
-  
- setStringAttribute(String, String) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-  
- setStringAttribute(String, String) - Method in interface com.hazelcast.core.Member
- 
Defines a key-value pair string attribute for this member available
 to other cluster members. 
- setStringAttribute(String, String) - Method in class com.hazelcast.instance.MemberImpl
-  
- setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.NetworkConfig
- 
- setSyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
- 
Deprecated. 
- setSyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-  
- setSynchronous(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
- 
If true, this cache entry listener implementation will be called
 in a synchronous manner. 
- setSynchronous(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
-  
- setSystemProperty(String) - Method in enum com.hazelcast.client.config.ClientProperty
-  
- setSystemProperty(String) - Method in enum com.hazelcast.instance.GroupProperty
-  
- setSystemProperty(String) - Method in interface com.hazelcast.instance.HazelcastProperty
- 
Sets the environmental value of the property. 
- setTagKey(String) - Method in class com.hazelcast.config.AwsConfig
- 
Sets the tag key. 
- setTagValue(String) - Method in class com.hazelcast.config.AwsConfig
- 
Sets the tag value. 
- setTargetAddress(Address) - Method in class com.hazelcast.cluster.impl.AbstractJoiner
-  
- setTargetAddress(Address) - Method in interface com.hazelcast.cluster.Joiner
-  
- setTargetClusterConfigs(List<WanTargetClusterConfig>) - Method in class com.hazelcast.config.WanReplicationConfig
-  
- setTcpIpConfig(TcpIpConfig) - Method in class com.hazelcast.config.JoinConfig
-  
- setTcpNoDelay(boolean) - Method in class com.hazelcast.client.config.SocketOptions
- 
Enable/disable TCP_NODELAY socket option. 
- setThisMember(MemberImpl) - Method in class com.hazelcast.logging.LoggingServiceImpl
-  
- setThreadId(long) - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-  
- setThreadId(long) - Method in class com.hazelcast.map.impl.operation.MapOperation
-  
- setThreadId(long) - Method in interface com.hazelcast.map.impl.tx.MapTxnOperation
-  
- setThreadId(long) - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-  
- setThreadId(long) - Method in class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-  
- setThreadId(long) - Static method in class com.hazelcast.util.ThreadUtil
- 
Set the thread id 
- setThreads(int) - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- setTime(long) - Method in class com.hazelcast.monitor.TimedMemberState
-  
- setTimeout(long, TimeUnit) - Method in class com.hazelcast.transaction.TransactionOptions
- 
Sets the timeout. 
- setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.MapConfig
- 
The maximum number of seconds for each entry to stay in the map. 
- setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.NearCacheConfig
- 
Sets the maximum number of seconds for each entry to stay in the near cache. 
- setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
-  
- setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.RingbufferConfig
- 
Sets the time to live in seconds. 
- setTopicConfigs(Map<String, TopicConfig>) - Method in class com.hazelcast.config.Config
-  
- setTopicOverloadPolicy(TopicOverloadPolicy) - Method in class com.hazelcast.client.config.ClientReliableTopicConfig
- 
Sets the TopicOverloadPolicy for this reliable topic. 
- setTopicOverloadPolicy(TopicOverloadPolicy) - Method in class com.hazelcast.config.ReliableTopicConfig
- 
Sets the TopicOverloadPolicy for this reliable topic. 
- setTopologyChangedStrategy(TopologyChangedStrategy) - Method in class com.hazelcast.config.JobTrackerConfig
- 
Sets how the map reduce framework will react on topology
 changes while executing a job. 
- setTopologyChangedStrategy(TopologyChangedStrategy) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
-  
- setTotalConnections(int) - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- setTotalPhysical(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- setTransactionContext(TransactionContext) - Method in interface com.hazelcast.client.ClientEndpoint
-  
- setTransactionContext(TransactionContext) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-  
- setTransactionId(String) - Method in class com.hazelcast.collection.impl.collection.TxCollectionItem
-  
- setTransactionId(String) - Method in class com.hazelcast.collection.impl.txnqueue.TxQueueItem
-  
- setTransactionTimeout(int) - Method in class com.hazelcast.client.proxy.txn.xa.XAResourceProxy
-  
- setTransactionTimeout(int) - Method in class com.hazelcast.client.txn.proxy.xa.XAResourceProxy
-  
- setTransactionTimeout(int) - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
-  
- setTransactionType(TransactionOptions.TransactionType) - Method in class com.hazelcast.transaction.TransactionOptions
- 
- setTrustedInterfaces(Set<String>) - Method in class com.hazelcast.config.MulticastConfig
- 
Sets the trusted interfaces. 
- setTryCount(int) - Method in class com.hazelcast.cluster.impl.JoinRequest
-  
- setTryCount(int) - Method in class com.hazelcast.spi.InvocationBuilder
- 
Sets the try count; the number of times this operation can be retried. 
- setTryPauseMillis(long) - Method in class com.hazelcast.spi.InvocationBuilder
- 
Sets the pause time in milliseconds. 
- setTtl(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- setTtl(long) - Method in interface com.hazelcast.map.impl.record.Record
-  
- setTtl(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
-  
- setTtl(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- setTtl(long) - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
-  
- setTtl(long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- setTxnId(String) - Method in class com.hazelcast.transaction.client.BaseTransactionRequest
-  
- setType(ConnectionType) - Method in class com.hazelcast.client.connection.nio.ClientConnection
-  
- setType(PermissionConfig.PermissionType) - Method in class com.hazelcast.config.PermissionConfig
-  
- setType(QuorumType) - Method in class com.hazelcast.config.QuorumConfig
-  
- setType(ConnectionType) - Method in interface com.hazelcast.nio.Connection
- 
Sets the type of the connection 
- setType(ConnectionType) - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-  
- setTypeClass(Class) - Method in class com.hazelcast.config.SerializerConfig
- 
Sets the type of the class that will be serialized via this implementation. 
- setTypeClassName(String) - Method in class com.hazelcast.config.SerializerConfig
- 
This method is called only if typeClass is not set. 
- setTypes(Class<K>, Class<V>) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setTypes(Class<K>, Class<V>) - Method in interface com.hazelcast.config.CacheConfiguration
- 
Sets the expected type of keys and values for a Cacheconfigured with thisConfiguration.
 
- setUnknownCount(long) - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-  
- setUnknownTime(long) - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-  
- setUpdateInterval(int) - Method in class com.hazelcast.config.ManagementCenterConfig
- 
Sets the time frequency (in seconds) for which Management Center will take
 information from the Hazelcast cluster. 
- setUpdateTime(long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-  
- setUptime(int) - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- setUriString(String) - Method in class com.hazelcast.config.CacheConfig
- 
Sets the URI string, which is the global identifier of the  ICache. 
- setUriString(String) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setUrl(String) - Method in class com.hazelcast.config.ManagementCenterConfig
- 
Sets the URL where management center will work. 
- setUsage(LoginModuleConfig.LoginModuleUsage) - Method in class com.hazelcast.config.LoginModuleConfig
-  
- setUsedHeap(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- setUsedNativeMemory(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-  
- setUseNativeByteOrder(boolean) - Method in class com.hazelcast.config.SerializationConfig
-  
- setUseNativeByteOrder(boolean) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- setUseNativeByteOrder(boolean) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
-  
- setUserContext(ConcurrentMap<String, Object>) - Method in class com.hazelcast.config.Config
-  
- setUsername(String) - Method in class com.hazelcast.security.UsernamePasswordCredentials
- 
Sets the user name. 
- setValidateTarget(boolean) - Method in class com.hazelcast.spi.Operation
-  
- setValidationTimeoutSeconds(int) - Method in class com.hazelcast.config.HotRestartPersistenceConfig
- 
Sets validation timeout for hot-restart process, includes validating
 cluster members expected to join and partition table on all cluster. 
- setValue(V) - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-  
- setValue(V) - Method in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-  
- setValue(V) - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheRecord
- 
- setValue(Data) - Method in class com.hazelcast.cache.impl.record.CacheDataRecord
-  
- setValue(Object) - Method in class com.hazelcast.cache.impl.record.CacheObjectRecord
-  
- setValue(V) - Method in interface com.hazelcast.cache.impl.record.CacheRecord
- 
- setValue(Data) - Method in class com.hazelcast.collection.impl.collection.CollectionItem
-  
- setValue(MemcacheEntry, boolean) - Method in class com.hazelcast.internal.ascii.memcache.GetCommand
-  
- setValue(byte[]) - Method in class com.hazelcast.internal.ascii.rest.RestValue
-  
- setValue(Object) - Method in class com.hazelcast.map.impl.LazyMapEntry
-  
- setValue(V) - Method in class com.hazelcast.map.impl.MapEntrySimple
-  
- setValue(Data) - Method in class com.hazelcast.map.impl.query.QueryResultRow
-  
- setValue(Object) - Method in class com.hazelcast.map.impl.querycache.event.DefaultQueryCacheEventData
-  
- setValue(Record<Data>, Object) - Method in class com.hazelcast.map.impl.record.DataRecordFactory
-  
- setValue(Record<Object>, Object) - Method in class com.hazelcast.map.impl.record.ObjectRecordFactory
-  
- setValue(V) - Method in interface com.hazelcast.map.impl.record.Record
-  
- setValue(Record<T>, Object) - Method in interface com.hazelcast.map.impl.record.RecordFactory
-  
- setValue(V) - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- setValue(Object) - Method in class com.hazelcast.query.impl.CachedQueryEntry
-  
- setValue(Object) - Method in class com.hazelcast.query.impl.QueryEntry
-  
- setValue(Data) - Method in class com.hazelcast.replicatedmap.impl.record.RecordMigrationInfo
-  
- setValue(V) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedMapEntryView
-  
- setValue(V, long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-  
- setValue(V) - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.EntryIterator
-  
- setValue(V) - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.EntryIterator
-  
- setValue(V) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap.SimpleEntry
-  
- setValue(V) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap.WriteThroughEntry
- 
Set our entry's value and writes it through to the map. 
- setValue(V) - Method in class com.hazelcast.util.SampleableConcurrentHashMap.SamplingEntry
-  
- setValue(V) - Method in class com.hazelcast.util.scheduler.ScheduledEntry
-  
- setValue(Object) - Method in class com.hazelcast.web.LocalCacheEntry
- 
Sets value. 
- setValueCollectionType(String) - Method in class com.hazelcast.config.MultiMapConfig
- 
Sets the collection type for the values of this MultiMap. 
- setValueCollectionType(MultiMapConfig.ValueCollectionType) - Method in class com.hazelcast.config.MultiMapConfig
- 
Sets the collection type for the values of this MultiMap. 
- setValueCollectionType(String) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-  
- setValueCollectionType(MultiMapConfig.ValueCollectionType) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-  
- setValueInternal(V, long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-  
- setValueType(String) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Sets the value type for this  ICache. 
- setValueType(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- setVersion(short) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
- 
Sets the version field value. 
- setVersion(byte) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- setVersion(byte) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
-  
- setVersion(long) - Method in class com.hazelcast.map.impl.record.AbstractRecord
-  
- setVersion(long) - Method in interface com.hazelcast.map.impl.record.Record
-  
- setVersion(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
-  
- setVersion(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
-  
- setVersion(long) - Method in interface com.hazelcast.map.impl.tx.MapTxnOperation
-  
- setVersion(long) - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-  
- setVersion(long) - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-  
- setVersion(long) - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-  
- setVersion(long) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-  
- setVersion(long) - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
-  
- setVersion(long) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- setWaitingRequests(int) - Method in class com.hazelcast.internal.ascii.memcache.Stats
-  
- setWaitTimeout(long) - Method in class com.hazelcast.spi.Operation
-  
- setWanReplicationConfigs(Map<String, WanReplicationConfig>) - Method in class com.hazelcast.config.Config
-  
- setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.CacheConfig
-  
- setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Sets the WAN target replication reference. 
- setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.MapConfig
- 
Sets the Wan target replication reference. 
- setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.MapConfigReadOnly
-  
- setWriteBatchSize(int) - Method in class com.hazelcast.config.MapStoreConfig
- 
Sets the number of operations to be included in each batch processing round. 
- setWriteBatchSize(int) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
-  
- setWriteBehindProcessor(WriteBehindProcessor) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-  
- setWriteBehindQueue(WriteBehindQueue<DelayedEntry>) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-  
- setWriteCoalescing(boolean) - Method in class com.hazelcast.config.MapStoreConfig
- 
- setWriteDelaySeconds(int) - Method in class com.hazelcast.config.MapStoreConfig
- 
Sets the number of seconds to delay before writing (storing) the dirty records
  
 Default value is  0. 
- setWriteDelaySeconds(int) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
-  
- setWriteThrough(boolean) - Method in class com.hazelcast.config.CacheConfigReadOnly
-  
- setWriteThrough(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
- 
Set if write-through caching should be used. 
- setWriteThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
- 
Enables or disables write-through for this  ICache: a write to the queue also loads
 the entry into the data store. 
- setWriteThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-  
- severe(String) - Method in class com.hazelcast.logging.AbstractLogger
-  
- severe(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
-  
- severe(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
-  
- severe(String) - Method in interface com.hazelcast.logging.ILogger
- 
- severe(Throwable) - Method in interface com.hazelcast.logging.ILogger
- 
- severe(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
- 
Logs message with associated throwable information at  Level.SEVERE. 
- SharedService - Interface in com.hazelcast.spi
- 
Marks a service which exposes its data (e.g. 
- SHORT_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
-  
- SHORT_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
-  
- SHORT_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
-  
- SHORT_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
- 
Short size in bytes 
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
-  
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
-  
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
-  
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
-  
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-  
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheMergeOperation
-  
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CachePutAllOperation
-  
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
-  
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
-  
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
-  
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
-  
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionClearOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionCompareAndRemoveOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.list.operations.ListRemoveOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.list.operations.ListSetOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.queue.operations.AddAllOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.queue.operations.ClearOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.queue.operations.DrainOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.queue.operations.RemoveOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionPrepareOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionRollbackOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPrepareOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollOperation
-  
- shouldBackup() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackOperation
-  
- shouldBackup - Variable in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
-  
- shouldBackup() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
-  
- shouldBackup - Variable in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
-  
- shouldBackup() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
-  
- shouldBackup() - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
-  
- shouldBackup() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
-  
- shouldBackup() - Method in class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
-  
- shouldBackup() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
-  
- shouldBackup() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
-  
- shouldBackup() - Method in class com.hazelcast.concurrent.lock.operations.LocalLockCleanupOperation
-  
- shouldBackup() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
-  
- shouldBackup() - Method in class com.hazelcast.concurrent.lock.operations.SignalOperation
-  
- shouldBackup() - Method in class com.hazelcast.concurrent.lock.operations.UnlockIfLeaseExpiredOperation
- 
This operation runs on both primary and backup
 If it is running on backup we should not send a backup operation 
- shouldBackup() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
-  
- shouldBackup() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
-  
- shouldBackup() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainOperation
-  
- shouldBackup() - Method in class com.hazelcast.concurrent.semaphore.operations.InitOperation
-  
- shouldBackup() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
-  
- shouldBackup() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
-  
- shouldBackup() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.BasePutOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.ClearOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.DeleteOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.EntryOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.EvictOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.MapFlushOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.MergeOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.PutIfAbsentOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.RemoveIfSameOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.RemoveOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.ReplaceOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.TryPutOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-  
- shouldBackup() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-  
- shouldBackup() - Method in class com.hazelcast.multimap.impl.operations.ClearOperation
-  
- shouldBackup() - Method in class com.hazelcast.multimap.impl.operations.MultiMapBackupAwareOperation
-  
- shouldBackup() - Method in class com.hazelcast.multimap.impl.operations.PutOperation
-  
- shouldBackup() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllOperation
-  
- shouldBackup() - Method in class com.hazelcast.multimap.impl.operations.RemoveOperation
-  
- shouldBackup() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
-  
- shouldBackup() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
-  
- shouldBackup() - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
-  
- shouldBackup() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
-  
- shouldBackup() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
-  
- shouldBackup() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
-  
- shouldBackup() - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
-  
- shouldBackup() - Method in interface com.hazelcast.spi.BackupAwareOperation
- 
Checks if a backup needs to be made. 
- shouldBackup() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
-  
- shouldBackup() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
-  
- shouldBackup() - Method in class com.hazelcast.transaction.impl.xa.operations.PutRemoteTransactionOperation
-  
- shouldBypassHeartbeatCheck() - Method in class com.hazelcast.client.spi.impl.ClientInvocation
-  
- shouldCancel(boolean) - Method in class com.hazelcast.mapreduce.impl.task.TrackableJobFuture
-  
- shouldCancel(boolean) - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
- 
Protected method invoked on cancel(). 
- shouldConnectTo(Address) - Method in interface com.hazelcast.nio.IOService
-  
- shouldConnectTo(Address) - Method in class com.hazelcast.nio.NodeIOService
-  
- shouldDoInitialLoad() - Method in class com.hazelcast.map.impl.MapKeyLoader
-  
- shouldHandle(OutOfMemoryError) - Method in class com.hazelcast.core.OutOfMemoryHandler
- 
Decides if the OutOfMemoryError thrown will be handled by this OutOfMemoryHandler or not. 
- shouldHandle(OutOfMemoryError) - Method in class com.hazelcast.instance.DefaultOutOfMemoryHandler
-  
- shouldIncludeValue() - Method in class com.hazelcast.client.impl.protocol.task.multimap.AbstractMultiMapAddEntryListenerMessageTask
-  
- shouldIncludeValue() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerMessageTask
-  
- shouldIncludeValue() - Method in class com.hazelcast.client.impl.protocol.task.multimap.MultiMapAddEntryListenerToKeyMessageTask
-  
- shouldNotify() - Method in class com.hazelcast.collection.impl.queue.operations.AddAllOperation
-  
- shouldNotify() - Method in class com.hazelcast.collection.impl.queue.operations.ClearOperation
-  
- shouldNotify() - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
-  
- shouldNotify() - Method in class com.hazelcast.collection.impl.queue.operations.DrainOperation
-  
- shouldNotify() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
-  
- shouldNotify() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
-  
- shouldNotify() - Method in class com.hazelcast.collection.impl.queue.operations.RemoveOperation
-  
- shouldNotify() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferOperation
-  
- shouldNotify() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollOperation
-  
- shouldNotify() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnRollbackOperation
-  
- shouldNotify() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
-  
- shouldNotify() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
-  
- shouldNotify() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
-  
- shouldNotify() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
-  
- shouldNotify() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-  
- shouldNotify() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-  
- shouldNotify() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
-  
- shouldNotify() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-  
- shouldNotify() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-  
- shouldNotify() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
-  
- shouldNotify() - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackOperation
-  
- shouldNotify() - Method in class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
-  
- shouldNotify() - Method in class com.hazelcast.ringbuffer.impl.operations.AddOperation
-  
- shouldNotify() - Method in interface com.hazelcast.spi.Notifier
-  
- shouldReply() - Method in class com.hazelcast.cluster.impl.BindMessage
-  
- shouldReply() - Method in class com.hazelcast.internal.ascii.AbstractTextCommand
-  
- shouldReply() - Method in class com.hazelcast.internal.ascii.memcache.DeleteCommand
-  
- shouldReply() - Method in class com.hazelcast.internal.ascii.memcache.IncrementCommand
-  
- shouldReply() - Method in class com.hazelcast.internal.ascii.memcache.SetCommand
-  
- shouldReply() - Method in class com.hazelcast.internal.ascii.memcache.TouchCommand
-  
- shouldReply() - Method in class com.hazelcast.internal.ascii.rest.HttpCommand
-  
- shouldReply() - Method in interface com.hazelcast.internal.ascii.TextCommand
-  
- shouldRetry() - Method in class com.hazelcast.client.spi.impl.ClientInvocation
-  
- shouldWait() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
-  
- shouldWait() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
-  
- shouldWait() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPeekOperation
-  
- shouldWait() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReserveOfferOperation
-  
- shouldWait() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnReservePollOperation
-  
- shouldWait(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-  
- shouldWait() - Method in class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
-  
- shouldWait() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
-  
- shouldWait() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
-  
- shouldWait() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
-  
- shouldWait() - Method in class com.hazelcast.map.impl.operation.ContainsKeyOperation
-  
- shouldWait() - Method in class com.hazelcast.map.impl.operation.GetEntryViewOperation
-  
- shouldWait() - Method in class com.hazelcast.map.impl.operation.GetOperation
-  
- shouldWait() - Method in class com.hazelcast.map.impl.operation.LockAwareOperation
-  
- shouldWait() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-  
- shouldWait() - Method in class com.hazelcast.map.impl.tx.TxnLockAndGetOperation
-  
- shouldWait() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-  
- shouldWait() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-  
- shouldWait() - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-  
- shouldWait() - Method in class com.hazelcast.multimap.impl.operations.CountOperation
-  
- shouldWait() - Method in class com.hazelcast.multimap.impl.operations.GetAllOperation
-  
- shouldWait() - Method in class com.hazelcast.multimap.impl.operations.MultiMapBackupAwareOperation
-  
- shouldWait() - Method in class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
-  
- shouldWait() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
-  
- shouldWait() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadManyOperation
-  
- shouldWait() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadOneOperation
-  
- shouldWait(long) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-  
- shouldWait() - Method in interface com.hazelcast.spi.WaitSupport
-  
- shutdown(boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-  
- shutdown() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-  
- shutdown() - Method in interface com.hazelcast.client.connection.ClientConnectionManager
- 
Shutdown clientConnectionManager 
- shutdown() - Method in class com.hazelcast.client.connection.nio.AbstractClientSelectionHandler
-  
- shutdown() - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-  
- shutdown() - Method in class com.hazelcast.client.connection.nio.ClientWriteHandler
-  
- shutdown(HazelcastInstance) - Static method in class com.hazelcast.client.HazelcastClient
- 
Shutdown the provided client and remove it from the managed list 
- shutdown(String) - Static method in class com.hazelcast.client.HazelcastClient
- 
Shutdown the provided client and remove it from the managed list 
- shutdown(boolean) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-  
- shutdown() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- shutdown() - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-  
- shutdown() - Method in class com.hazelcast.client.impl.LifecycleServiceImpl
-  
- shutdown() - Method in class com.hazelcast.client.proxy.ClientClusterProxy
-  
- shutdown(TransactionOptions) - Method in class com.hazelcast.client.proxy.ClientClusterProxy
-  
- shutdown() - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- shutdown() - Method in interface com.hazelcast.client.spi.ClientInvocationService
-  
- shutdown() - Method in interface com.hazelcast.client.spi.ClientTransactionManagerService
-  
- shutdown() - Method in class com.hazelcast.client.spi.impl.ClientExecutionServiceImpl
-  
- shutdown() - Method in class com.hazelcast.client.spi.impl.ClientTransactionManagerServiceImpl
-  
- shutdown() - Method in class com.hazelcast.client.spi.impl.ClusterListenerSupport
-  
- shutdown() - Method in class com.hazelcast.client.spi.impl.listener.ClientListenerServiceImpl
-  
- shutdown() - Method in class com.hazelcast.client.spi.impl.listener.ClientSmartListenerService
-  
- shutdown(boolean) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- shutdown() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- shutdown(TransactionOptions) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-  
- shutdown(boolean) - Method in class com.hazelcast.collection.impl.collection.CollectionService
-  
- shutdown(boolean) - Method in class com.hazelcast.collection.impl.queue.QueueService
-  
- shutdown(boolean) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-  
- shutdown(boolean) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-  
- shutdown(boolean) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-  
- shutdown(boolean) - Method in class com.hazelcast.concurrent.idgen.IdGeneratorService
-  
- shutdown(boolean) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-  
- shutdown(boolean) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-  
- shutdown() - Method in interface com.hazelcast.core.Cluster
- 
Changes state of the cluster to the  ClusterState.PASSIVE transactionally,
 then triggers the shutdown process on each node. 
- shutdown(TransactionOptions) - Method in interface com.hazelcast.core.Cluster
- 
Changes state of the cluster to the  ClusterState.PASSIVE transactionally, then
 triggers the shutdown process on each node. 
- shutdown() - Method in interface com.hazelcast.core.HazelcastInstance
- 
Shuts down this HazelcastInstance. 
- shutdown() - Method in interface com.hazelcast.core.LifecycleService
- 
gracefully shutdowns HazelcastInstance. 
- shutdown(boolean) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-  
- shutdown() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- shutdown() - Method in class com.hazelcast.instance.DefaultNodeExtension
-  
- shutdown() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-  
- shutdown() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-  
- shutdown() - Method in class com.hazelcast.instance.LifecycleServiceImpl
-  
- shutdown(boolean) - Method in class com.hazelcast.instance.Node
-  
- shutdown() - Method in interface com.hazelcast.instance.NodeExtension
- 
Shutdowns NodeExtension. 
- shutdown() - Method in class com.hazelcast.instance.TerminatedLifecycleService
-  
- shutdown() - Method in class com.hazelcast.internal.management.ManagementCenterService
-  
- shutdown() - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
-  
- shutdown() - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-  
- shutdown() - Method in class com.hazelcast.jmx.InstanceMBean
-  
- shutdown(boolean) - Method in class com.hazelcast.map.impl.MapManagedService
-  
- shutdown(boolean) - Method in class com.hazelcast.map.impl.MapService
-  
- shutdown() - Method in interface com.hazelcast.map.impl.MapServiceContext
- 
Releases internal resources solely managed by Hazelcast. 
- shutdown() - Method in class com.hazelcast.map.impl.nearcache.BatchInvalidator
-  
- shutdown() - Method in interface com.hazelcast.map.impl.nearcache.NearCacheInvalidator
- 
Shuts down this invalidator and releases used resources. 
- shutdown() - Method in class com.hazelcast.map.impl.nearcache.NearCacheProvider
-  
- shutdown() - Method in class com.hazelcast.map.impl.nearcache.NonStopInvalidator
-  
- shutdown(boolean) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-  
- shutdown(boolean) - Method in class com.hazelcast.multimap.impl.MultiMapService
-  
- shutdown() - Method in interface com.hazelcast.nio.ConnectionManager
- 
Shutdowns ConnectionManager completely. 
- shutdown() - Method in interface com.hazelcast.nio.tcp.IOThreadingModel
- 
Shuts down the IOThreadingModel. 
- shutdown() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingIOThread
-  
- shutdown() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingIOThreadingModel
-  
- shutdown() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingSocketWriter
-  
- shutdown() - Method in class com.hazelcast.nio.tcp.SocketAcceptorThread
-  
- shutdown() - Method in interface com.hazelcast.nio.tcp.SocketWriter
- 
Shuts down this SocketWriter. 
- shutdown() - Method in class com.hazelcast.nio.tcp.spinning.SpinningInputThread
-  
- shutdown() - Method in class com.hazelcast.nio.tcp.spinning.SpinningIOThreadingModel
-  
- shutdown() - Method in class com.hazelcast.nio.tcp.spinning.SpinningOutputThread
-  
- shutdown() - Method in class com.hazelcast.nio.tcp.spinning.SpinningSocketWriter
-  
- shutdown() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- shutdown(boolean) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-  
- shutdown() - Method in class com.hazelcast.replicatedmap.impl.PartitionContainer
-  
- shutdown(boolean) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-  
- shutdown(boolean) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-  
- shutdown() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceImpl
-  
- shutdown() - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-  
- shutdown(boolean) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- shutdown() - Method in class com.hazelcast.spi.impl.operationexecutor.classic.ClassicOperationExecutor
-  
- shutdown() - Method in class com.hazelcast.spi.impl.operationexecutor.classic.OperationThread
-  
- shutdown() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
- 
Shuts down this OperationExecutor. 
- shutdown() - Method in class com.hazelcast.spi.impl.operationexecutor.slowoperationdetector.SlowOperationDetector
-  
- shutdown() - Method in class com.hazelcast.spi.impl.operationservice.impl.AsyncResponsePacketHandler
-  
- shutdown() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationMonitor
-  
- shutdown() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
-  
- shutdown() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- shutdown() - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-  
- shutdown(boolean) - Method in class com.hazelcast.spi.impl.servicemanager.impl.ServiceManagerImpl
-  
- shutdown() - Method in class com.hazelcast.spi.impl.waitnotifyservice.impl.WaitNotifyServiceImpl
-  
- shutdown(boolean) - Method in interface com.hazelcast.spi.ManagedService
- 
Shuts down this ManagedService. 
- shutdown(boolean) - Method in class com.hazelcast.topic.impl.TopicService
-  
- shutdown(boolean) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-  
- shutdown(boolean) - Method in class com.hazelcast.transaction.impl.xa.XAService
-  
- shutdown() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-  
- shutdown() - Method in class com.hazelcast.util.executor.StripedExecutor
- 
Shuts down this StripedExecutor. 
- shutdown() - Method in class com.hazelcast.util.PhoneHome
-  
- shutdown() - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
-  
- shutdown() - Method in interface com.hazelcast.wan.WanReplicationEndpoint
- 
Closes the endpoint and its internal connections and shuts down other internal states 
- shutdown() - Method in interface com.hazelcast.wan.WanReplicationService
- 
Starts the shutdown process of the WAN replication service. 
- SHUTDOWN_ON_STOP - Static variable in class com.hazelcast.hibernate.CacheEnvironment
- 
Property to configure if the HazelcastInstance should going to shutdown when the RegionFactory is being stopped 
- SHUTDOWN_REQUEST - Static variable in class com.hazelcast.executor.impl.ExecutorPortableHook
-  
- shutdownAll() - Static method in class com.hazelcast.client.HazelcastClient
- 
Shuts down all the client HazelcastInstance created in this JVM. 
- shutdownAll() - Static method in class com.hazelcast.core.Hazelcast
- 
Shuts down all running Hazelcast Instances on this JVM. 
- shutdownAll() - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
-  
- shutdownAll() - Static method in class com.hazelcast.jmx.ManagementService
-  
- shutdownAll() - Method in interface com.hazelcast.osgi.HazelcastOSGiService
- 
- ShutdownClusterRequest - Class in com.hazelcast.internal.management.request
- 
Request coming from Management Center for shutting down the  Cluster
- ShutdownClusterRequest() - Constructor for class com.hazelcast.internal.management.request.ShutdownClusterRequest
-  
- shutdownExecutor(String, ExecutorService, ILogger) - Static method in class com.hazelcast.client.spi.impl.ClientExecutionServiceImpl
-  
- shutdownExecutor(String) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-  
- shutdownExecutor(String) - Method in interface com.hazelcast.spi.ExecutionService
-  
- shutdownExecutor(String) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-  
- shutdownHazelcastInstance() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-  
- shutdownHazelcastInstance(HazelcastOSGiInstance) - Method in interface com.hazelcast.osgi.HazelcastOSGiService
- 
- ShutdownMemberRequest - Class in com.hazelcast.internal.management.request
- 
Request for shutting down the member. 
- ShutdownMemberRequest() - Constructor for class com.hazelcast.internal.management.request.ShutdownMemberRequest
-  
- shutdownNodeByFiringEvents(Node, boolean) - Static method in class com.hazelcast.instance.NodeShutdownHelper
- 
Shutdowns a node by firing lifecycle events. 
- ShutdownNodeOperation - Class in com.hazelcast.cluster.impl.operations
-  
- ShutdownNodeOperation() - Constructor for class com.hazelcast.cluster.impl.operations.ShutdownNodeOperation
-  
- shutdownNow() - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- shutdownNow() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- shutdownNow() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-  
- shutdownOnStop(Properties, boolean) - Static method in class com.hazelcast.hibernate.CacheEnvironment
-  
- ShutdownOperation - Class in com.hazelcast.executor.impl.operations
-  
- ShutdownOperation() - Constructor for class com.hazelcast.executor.impl.operations.ShutdownOperation
-  
- ShutdownOperation(String) - Constructor for class com.hazelcast.executor.impl.operations.ShutdownOperation
-  
- ShutdownRequest - Class in com.hazelcast.executor.impl.client
-  
- ShutdownRequest() - Constructor for class com.hazelcast.executor.impl.client.ShutdownRequest
-  
- ShutdownRequest(String) - Constructor for class com.hazelcast.executor.impl.client.ShutdownRequest
-  
- shutdownSelectors() - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-  
- sign(String, Map<String, String>) - Method in class com.hazelcast.aws.security.EC2RequestSigner
-  
- signal() - Method in class com.hazelcast.client.proxy.ClientConditionProxy
-  
- SIGNAL - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
-  
- SIGNAL_BACKUP - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
-  
- signalAll() - Method in class com.hazelcast.client.proxy.ClientConditionProxy
-  
- SignalBackupOperation - Class in com.hazelcast.concurrent.lock.operations
-  
- SignalBackupOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.SignalBackupOperation
-  
- SignalBackupOperation(ObjectNamespace, Data, long, String, boolean) - Constructor for class com.hazelcast.concurrent.lock.operations.SignalBackupOperation
-  
- signalMigrationComplete() - Method in class com.hazelcast.nio.tcp.nonblocking.iobalancer.IOBalancer
-  
- SignalOperation - Class in com.hazelcast.concurrent.lock.operations
-  
- SignalOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.SignalOperation
-  
- SignalOperation(ObjectNamespace, Data, long, String, boolean) - Constructor for class com.hazelcast.concurrent.lock.operations.SignalOperation
-  
- SignalRequest - Class in com.hazelcast.concurrent.lock.client
-  
- SignalRequest() - Constructor for class com.hazelcast.concurrent.lock.client.SignalRequest
-  
- SignalRequest(ObjectNamespace, String, long, String, boolean) - Constructor for class com.hazelcast.concurrent.lock.client.SignalRequest
-  
- SIGNATURE_METHOD_V4 - Static variable in class com.hazelcast.aws.impl.Constants
-  
- SimpleCommand - Class in com.hazelcast.internal.ascii.memcache
-  
- SimpleCommand(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.internal.ascii.memcache.SimpleCommand
-  
- SimpleCommandParser - Class in com.hazelcast.internal.ascii.memcache
-  
- SimpleCommandParser(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.internal.ascii.memcache.SimpleCommandParser
-  
- SimpleCommandProcessor - Class in com.hazelcast.internal.ascii.memcache
-  
- SimpleCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.memcache.SimpleCommandProcessor
-  
- SimpleDiscoveryNode - Class in com.hazelcast.spi.discovery
- 
- SimpleDiscoveryNode(Address) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
- 
This constructor will set private and public addresses to the same value and no properties
 are available. 
- SimpleDiscoveryNode(Address, Map<String, Object>) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
- 
This constructor will set private and public addresses to the same value. 
- SimpleDiscoveryNode(Address, Address) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
- 
This constructor will set private and public addresses separately and no properties are available. 
- SimpleDiscoveryNode(Address, Address, Map<String, Object>) - Constructor for class com.hazelcast.spi.discovery.SimpleDiscoveryNode
- 
This constructor will set private and public addresses separately. 
- SimpleEntryView<K,V> - Class in com.hazelcast.map.impl
- 
SimpleEntryView is an implementation of  EntryView and also it is writable. 
- SimpleEntryView(K, V) - Constructor for class com.hazelcast.map.impl.SimpleEntryView
-  
- SimpleEntryView() - Constructor for class com.hazelcast.map.impl.SimpleEntryView
-  
- SimpleExecutionCallback<E> - Class in com.hazelcast.spi.impl
- 
A ExecutionCallback implementation that simplifies the implementation of the ExecutionCallback by only
 needing to implement a single method. 
- SimpleExecutionCallback() - Constructor for class com.hazelcast.spi.impl.SimpleExecutionCallback
-  
- SimplePropertyDefinition - Class in com.hazelcast.config.properties
- 
- SimplePropertyDefinition(String, TypeConverter) - Constructor for class com.hazelcast.config.properties.SimplePropertyDefinition
-  
- SimplePropertyDefinition(String, boolean, TypeConverter) - Constructor for class com.hazelcast.config.properties.SimplePropertyDefinition
-  
- SimplePropertyDefinition(String, boolean, TypeConverter, ValueValidator) - Constructor for class com.hazelcast.config.properties.SimplePropertyDefinition
-  
- SimulateLoadTask - Class in com.hazelcast.console
- 
A simulated load test 
- SimulateLoadTask(int, int, String) - Constructor for class com.hazelcast.console.SimulateLoadTask
-  
- SingleExecutorThreadFactory - Class in com.hazelcast.util.executor
-  
- SingleExecutorThreadFactory(ThreadGroup, ClassLoader, String) - Constructor for class com.hazelcast.util.executor.SingleExecutorThreadFactory
-  
- SingleExecutorThreadFactory(HazelcastThreadGroup, String) - Constructor for class com.hazelcast.util.executor.SingleExecutorThreadFactory
-  
- SingleMemberGroup - Class in com.hazelcast.partition.membergroup
-  
- SingleMemberGroup() - Constructor for class com.hazelcast.partition.membergroup.SingleMemberGroup
-  
- SingleMemberGroup(Member) - Constructor for class com.hazelcast.partition.membergroup.SingleMemberGroup
-  
- SingleMemberGroupFactory - Class in com.hazelcast.partition.membergroup
-  
- SingleMemberGroupFactory() - Constructor for class com.hazelcast.partition.membergroup.SingleMemberGroupFactory
-  
- SingleNearCacheInvalidation - Class in com.hazelcast.map.impl.nearcache
-  
- SingleNearCacheInvalidation() - Constructor for class com.hazelcast.map.impl.nearcache.SingleNearCacheInvalidation
-  
- SingleNearCacheInvalidation(String, Data, String) - Constructor for class com.hazelcast.map.impl.nearcache.SingleNearCacheInvalidation
-  
- SingleResultSet - Class in com.hazelcast.query.impl
- 
Multiple result set for Predicates. 
- SingleResultSet(ConcurrentMap<Data, QueryableEntry>) - Constructor for class com.hazelcast.query.impl.SingleResultSet
-  
- size() - Method in interface com.hazelcast.cache.ICache
- 
Total entry count. 
- size() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- SIZE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- SIZE - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-  
- size() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
- 
Calculates the entry size of this store which reflects the partition size of the cache. 
- size() - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache
-  
- size() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- size() - Method in interface com.hazelcast.cache.impl.nearcache.NearCache
- 
Gets the count of stored records. 
- size() - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheRecordStore
- 
Gets the number of stored records. 
- size() - Method in interface com.hazelcast.client.ClientEndpointManager
- 
Returns the current number of endpoints. 
- size() - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-  
- size() - Method in class com.hazelcast.client.map.impl.nearcache.ClientHeapNearCache
-  
- size() - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
-  
- size() - Method in class com.hazelcast.client.proxy.ClientListProxy
-  
- size() - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- size() - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-  
- size() - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-  
- size() - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-  
- size() - Method in class com.hazelcast.client.proxy.ClientRingbufferProxy
-  
- size() - Method in class com.hazelcast.client.proxy.ClientSetProxy
-  
- size() - Method in class com.hazelcast.client.proxy.txn.ClientTxnListProxy
-  
- size() - Method in class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-  
- size() - Method in class com.hazelcast.client.proxy.txn.ClientTxnMultiMapProxy
-  
- size() - Method in class com.hazelcast.client.proxy.txn.ClientTxnQueueProxy
-  
- size() - Method in class com.hazelcast.client.proxy.txn.ClientTxnSetProxy
-  
- size() - Method in class com.hazelcast.client.txn.proxy.ClientTxnListProxy
-  
- size() - Method in class com.hazelcast.client.txn.proxy.ClientTxnMapProxy
-  
- size() - Method in class com.hazelcast.client.txn.proxy.ClientTxnMultiMapProxy
-  
- size() - Method in class com.hazelcast.client.txn.proxy.ClientTxnQueueProxy
-  
- size() - Method in class com.hazelcast.client.txn.proxy.ClientTxnSetProxy
-  
- size() - Method in class com.hazelcast.cluster.impl.MemberSelectingCollection
-  
- size() - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-  
- size() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-  
- size() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-  
- SIZE - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-  
- SIZE - Static variable in class com.hazelcast.collection.impl.queue.QueuePortableHook
-  
- size() - Method in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
-  
- size() - Method in class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxySupport
-  
- size - Variable in class com.hazelcast.config.EvictionConfig
-  
- size() - Method in interface com.hazelcast.core.BaseMap
- 
Returns the number of entries in this map. 
- size() - Method in interface com.hazelcast.core.BaseMultiMap
- 
Returns the number of key-value pairs in the multimap. 
- size() - Method in interface com.hazelcast.core.BaseQueue
- 
Returns the number of elements in this collection. 
- size() - Method in interface com.hazelcast.core.MultiMap
- 
Returns the number of key-value pairs in the multimap. 
- size() - Method in interface com.hazelcast.core.TransactionalList
- 
Returns the size of the list 
- size() - Method in interface com.hazelcast.core.TransactionalMap
- 
- size() - Method in interface com.hazelcast.core.TransactionalMultiMap
- 
Returns the number of key-value pairs in the multimap. 
- size() - Method in interface com.hazelcast.core.TransactionalQueue
- 
Returns the number of elements in this collection. 
- size() - Method in interface com.hazelcast.core.TransactionalSet
- 
Returns the size of the set. 
- size() - Method in class com.hazelcast.hibernate.distributed.IMapRegionCache
-  
- size() - Method in class com.hazelcast.hibernate.local.LocalRegionCache
-  
- size() - Method in interface com.hazelcast.hibernate.RegionCache
-  
- size(String) - Method in interface com.hazelcast.internal.ascii.TextCommandService
- 
Returns the size of the distributed queue instance with the specified name 
- size(String) - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- size() - Method in class com.hazelcast.map.impl.MapEntries
-  
- SIZE - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- size() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
- 
- size() - Method in class com.hazelcast.map.impl.nearcache.NearCacheImpl
-  
- size() - Method in class com.hazelcast.map.impl.query.QueryResult
-  
- size() - Method in class com.hazelcast.map.impl.query.QueryResultCollection
-  
- size() - Method in class com.hazelcast.map.impl.query.SortedQueryResultSet
-  
- size() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
- 
Size may not give precise size at a specific moment
 due to the expiration logic. 
- size() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-  
- size() - Method in interface com.hazelcast.map.impl.recordstore.Storage
-  
- size() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-  
- size() - Method in interface com.hazelcast.map.QueryCache
-  
- size() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-  
- SIZE - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- SIZE - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-  
- size() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-  
- size() - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
-  
- size() - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-  
- size() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
-  
- size() - Method in interface com.hazelcast.partition.membergroup.MemberGroup
-  
- size() - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
-  
- size() - Method in class com.hazelcast.query.impl.AndResultSet
-  
- size() - Method in class com.hazelcast.query.impl.DuplicateDetectingMultiResult
-  
- size() - Method in class com.hazelcast.query.impl.FastMultiResultSet
-  
- size() - Method in class com.hazelcast.query.impl.OrResultSet
-  
- size() - Method in class com.hazelcast.query.impl.SingleResultSet
-  
- SIZE - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-  
- size() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-  
- size() - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
-  
- size() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- size() - Method in class com.hazelcast.replicatedmap.impl.record.ResultSet
-  
- size() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-  
- SIZE - Static variable in class com.hazelcast.ringbuffer.impl.client.RingbufferPortableHook
-  
- size() - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
-  
- size() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-  
- size() - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
-  
- size() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
- 
Returns number of items in the ringbuffer. 
- size() - Method in class com.hazelcast.spi.impl.operationexecutor.classic.DefaultScheduleQueue
-  
- size() - Method in interface com.hazelcast.spi.impl.operationexecutor.classic.ScheduleQueue
- 
Returns the total number of pending operations. 
- size() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
- 
Returns the number of pending invocations. 
- size() - Method in class com.hazelcast.spi.impl.SerializableList
-  
- size() - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
-  
- size() - Method in class com.hazelcast.transaction.impl.TransactionLog
- 
Returns the number of TransactionRecords in this TransactionLog. 
- size() - Method in class com.hazelcast.util.collection.BiInt2ObjectMap
- 
Return the number of unique entries in the map. 
- size() - Method in class com.hazelcast.util.collection.InflatableSet
-  
- size() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
-  
- size() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
- size() - Method in class com.hazelcast.util.collection.IntHashSet
- size() - Method in class com.hazelcast.util.collection.Long2LongHashMap
- size() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
-  
- size() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
- size() - Method in class com.hazelcast.util.collection.LongHashSet
- size() - Method in class com.hazelcast.util.collection.MapDelegatingSet
- size() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
- 
Returns the number of key-value mappings in this map. 
- SIZE_FACTORY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-  
- SizeEstimator<T> - Interface in com.hazelcast.map.impl
- 
Size estimator general contract. 
- SizeEstimators - Class in com.hazelcast.map.impl
- 
Static factory methods for various size estimators. 
- sizeInternal() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-  
- SizeOperation - Class in com.hazelcast.collection.impl.queue.operations
- 
Notify size of the queue. 
- SizeOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.SizeOperation
-  
- SizeOperation(String) - Constructor for class com.hazelcast.collection.impl.queue.operations.SizeOperation
-  
- SizeOperation - Class in com.hazelcast.multimap.impl.operations
-  
- SizeOperation() - Constructor for class com.hazelcast.multimap.impl.operations.SizeOperation
-  
- SizeOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.SizeOperation
-  
- SizeOperation - Class in com.hazelcast.replicatedmap.impl.operation
-  
- SizeOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.SizeOperation
-  
- SizeOperation(String) - Constructor for class com.hazelcast.replicatedmap.impl.operation.SizeOperation
-  
- SizeOperationFactory - Class in com.hazelcast.map.impl.operation
-  
- SizeOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.SizeOperationFactory
-  
- SizeOperationFactory(String) - Constructor for class com.hazelcast.map.impl.operation.SizeOperationFactory
-  
- SizeRequest - Class in com.hazelcast.collection.impl.queue.client
- 
Request for size of the Queue. 
- SizeRequest() - Constructor for class com.hazelcast.collection.impl.queue.client.SizeRequest
-  
- SizeRequest(String) - Constructor for class com.hazelcast.collection.impl.queue.client.SizeRequest
-  
- SizeRequest - Class in com.hazelcast.multimap.impl.client
-  
- SizeRequest() - Constructor for class com.hazelcast.multimap.impl.client.SizeRequest
-  
- SizeRequest(String) - Constructor for class com.hazelcast.multimap.impl.client.SizeRequest
-  
- SizeRequest - Class in com.hazelcast.ringbuffer.impl.client
-  
- SizeRequest() - Constructor for class com.hazelcast.ringbuffer.impl.client.SizeRequest
-  
- SizeRequest(String) - Constructor for class com.hazelcast.ringbuffer.impl.client.SizeRequest
-  
- skip(long) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- skipBytes(int) - Method in class com.hazelcast.internal.serialization.impl.ObjectDataInputStream
-  
- skipRegistration(Invocation) - Method in class com.hazelcast.spi.impl.operationservice.impl.CallIdSequence
- 
Not every call needs to be registered. 
- sleep() - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
-  
- Slf4jFactory - Class in com.hazelcast.logging
-  
- Slf4jFactory() - Constructor for class com.hazelcast.logging.Slf4jFactory
-  
- SlowOperationDetector - Class in com.hazelcast.spi.impl.operationexecutor.slowoperationdetector
- 
- SlowOperationDetector(LoggingService, OperationRunner[], OperationRunner[], GroupProperties, HazelcastThreadGroup) - Constructor for class com.hazelcast.spi.impl.operationexecutor.slowoperationdetector.SlowOperationDetector
-  
- SlowOperationDTO - Class in com.hazelcast.internal.management.dto
- 
A Serializable DTO for SlowOperationLog.
 
- SlowOperationDTO() - Constructor for class com.hazelcast.internal.management.dto.SlowOperationDTO
-  
- SlowOperationDTO(String, String, int, List<SlowOperationInvocationDTO>) - Constructor for class com.hazelcast.internal.management.dto.SlowOperationDTO
-  
- SlowOperationInvocationDTO - Class in com.hazelcast.internal.management.dto
- 
A Serializable DTO for SlowOperationLog.Invocation.
 
- SlowOperationInvocationDTO() - Constructor for class com.hazelcast.internal.management.dto.SlowOperationInvocationDTO
-  
- SlowOperationInvocationDTO(int, String, long, int) - Constructor for class com.hazelcast.internal.management.dto.SlowOperationInvocationDTO
-  
- sneakyThrow(Throwable) - Static method in class com.hazelcast.util.ExceptionUtil
-  
- SOCKET - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- socket() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-  
- socket() - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-  
- SocketAcceptorThread - Class in com.hazelcast.nio.tcp
-  
- SocketAcceptorThread(ThreadGroup, String, ServerSocketChannel, TcpIpConnectionManager) - Constructor for class com.hazelcast.nio.tcp.SocketAcceptorThread
-  
- socketChannel - Variable in class com.hazelcast.client.connection.nio.AbstractClientSelectionHandler
-  
- socketChannel - Variable in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-  
- socketChannel - Variable in class com.hazelcast.nio.tcp.nonblocking.AbstractHandler
-  
- SocketChannelWrapper - Interface in com.hazelcast.nio.tcp
- 
- SocketChannelWrapperFactory - Interface in com.hazelcast.nio.tcp
- 
- SocketInterceptor - Interface in com.hazelcast.nio
- 
An interface that provides the ability to intercept the creation of sockets. 
- SocketInterceptorConfig - Class in com.hazelcast.config
- 
Contains the configuration for interceptor socket 
- SocketInterceptorConfig() - Constructor for class com.hazelcast.config.SocketInterceptorConfig
-  
- SocketOptions - Class in com.hazelcast.client.config
- 
TCP Socket options 
- SocketOptions() - Constructor for class com.hazelcast.client.config.SocketOptions
-  
- SocketReader - Interface in com.hazelcast.nio.tcp
- 
The SocketReader is responsible for reading data from the socket, on behalf of a connection, into a
  ByteBuffer. 
- SocketWriter - Interface in com.hazelcast.nio.tcp
- 
- SortedIndexStore - Class in com.hazelcast.query.impl
- 
Store indexes rankly. 
- SortedIndexStore() - Constructor for class com.hazelcast.query.impl.SortedIndexStore
-  
- SortedQueryResultSet - Class in com.hazelcast.map.impl.query
- 
Collection class for results of query operations 
- SortedQueryResultSet() - Constructor for class com.hazelcast.map.impl.query.SortedQueryResultSet
-  
- SortedQueryResultSet(List<Map.Entry>, IterationType) - Constructor for class com.hazelcast.map.impl.query.SortedQueryResultSet
-  
- SortingUtil - Class in com.hazelcast.util
- 
Utility class for generating Comparators to be used in sort methods specific to hazelcast classes. 
- SOURCE_NOT_AVAILABLE - Static variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- SPACE - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
-  
- SPECIFIC_TARGET_CALLABLE_REQUEST - Static variable in class com.hazelcast.executor.impl.ExecutorPortableHook
-  
- SpecificTargetCallableRequest - Class in com.hazelcast.executor.impl.client
- 
- SpecificTargetCallableRequest() - Constructor for class com.hazelcast.executor.impl.client.SpecificTargetCallableRequest
-  
- SpecificTargetCallableRequest(String, String, Callable, Address) - Constructor for class com.hazelcast.executor.impl.client.SpecificTargetCallableRequest
-  
- SPI_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- SPI_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- SPI_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- SPI_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-  
- SpiDataSerializerHook - Class in com.hazelcast.spi.impl
-  
- SpiDataSerializerHook() - Constructor for class com.hazelcast.spi.impl.SpiDataSerializerHook
-  
- SpinningInputThread - Class in com.hazelcast.nio.tcp.spinning
-  
- SpinningInputThread(HazelcastThreadGroup, ILogger) - Constructor for class com.hazelcast.nio.tcp.spinning.SpinningInputThread
-  
- SpinningIOThreadingModel - Class in com.hazelcast.nio.tcp.spinning
- 
A  IOThreadingModel that uses (busy) spinning on the SocketChannels to see if there is something
 to read or write. 
- SpinningIOThreadingModel(IOService, LoggingService, MetricsRegistry, HazelcastThreadGroup) - Constructor for class com.hazelcast.nio.tcp.spinning.SpinningIOThreadingModel
-  
- SpinningOutputThread - Class in com.hazelcast.nio.tcp.spinning
-  
- SpinningOutputThread(HazelcastThreadGroup, ILogger) - Constructor for class com.hazelcast.nio.tcp.spinning.SpinningOutputThread
-  
- SpinningSocketReader - Class in com.hazelcast.nio.tcp.spinning
-  
- SpinningSocketReader(TcpIpConnection, MetricsRegistry, ILogger) - Constructor for class com.hazelcast.nio.tcp.spinning.SpinningSocketReader
-  
- SpinningSocketWriter - Class in com.hazelcast.nio.tcp.spinning
-  
- SpinningSocketWriter(TcpIpConnection, MetricsRegistry, ILogger) - Constructor for class com.hazelcast.nio.tcp.spinning.SpinningSocketWriter
-  
- SpiPortableHook - Class in com.hazelcast.spi.impl
-  
- SpiPortableHook() - Constructor for class com.hazelcast.spi.impl.SpiPortableHook
-  
- SplitBrainAwareCacheRecordStore - Interface in com.hazelcast.cache.impl
- 
Contract point for  ICacheRecordStore implementations
 which are handled in split-brain. 
- splitBrainHandlerService - Variable in class com.hazelcast.map.impl.MapService
-  
- SplitBrainHandlerService - Interface in com.hazelcast.spi
- 
An interface that can be implemented by SPI services that want to be able to resolve a split brain. 
- SpringAware - Annotation Type in com.hazelcast.spring.context
- 
Annotates a class for injection of Spring dependencies. 
- SpringAwareWebFilter - Class in com.hazelcast.web.spring
- 
Provides Spring aware Hazelcast based session replication by extending from
  WebFilter
- SpringAwareWebFilter() - Constructor for class com.hazelcast.web.spring.SpringAwareWebFilter
-  
- SpringAwareWebFilter(Properties) - Constructor for class com.hazelcast.web.spring.SpringAwareWebFilter
-  
- SpringHazelcastCachingProvider - Class in com.hazelcast.spring.cache
- 
- SpringManagedContext - Class in com.hazelcast.spring.context
-  
- SpringManagedContext() - Constructor for class com.hazelcast.spring.context.SpringManagedContext
-  
- sql - Variable in class com.hazelcast.config.PredicateConfig
-  
- SQL_DATE_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
-  
- SQL_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
-  
- SQL_QUERY - Static variable in class com.hazelcast.map.impl.MapPortableHook
-  
- SQL_TIMESTAMP_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
-  
- SqlPredicate - Class in com.hazelcast.query
- 
This class contains methods related to conversion of sql query to predicate. 
- SqlPredicate(String) - Constructor for class com.hazelcast.query.SqlPredicate
-  
- SqlPredicate() - Constructor for class com.hazelcast.query.SqlPredicate
-  
- SSLConfig - Class in com.hazelcast.config
- 
SSL configuration 
- SSLConfig() - Constructor for class com.hazelcast.config.SSLConfig
-  
- SSLContextFactory - Interface in com.hazelcast.nio.ssl
- 
- STACK_OVERFLOW_ERROR - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- stackTrace - Variable in class com.hazelcast.internal.management.dto.SlowOperationDTO
-  
- STALE_SEQUENCE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-  
- StaleSequenceException - Exception in com.hazelcast.ringbuffer
- 
An  RuntimeException that is thrown when accessing an item in the  Ringbuffer using a sequence that is smaller
 than the current head sequence. 
- StaleSequenceException(String, long) - Constructor for exception com.hazelcast.ringbuffer.StaleSequenceException
- 
Creates a SequenceOutOfBoundsException with the given message. 
- StandardLoggerFactory - Class in com.hazelcast.logging
-  
- StandardLoggerFactory() - Constructor for class com.hazelcast.logging.StandardLoggerFactory
-  
- start - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-  
- start() - Method in interface com.hazelcast.client.connection.ClientConnectionManager
- 
Start clientConnectionManager 
- start() - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-  
- start(String[]) - Method in class com.hazelcast.client.console.ClientConsoleApp
-  
- start() - Method in class com.hazelcast.client.impl.ClientHeartbeatMonitor
-  
- start() - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-  
- start(Xid, int) - Method in class com.hazelcast.client.proxy.txn.xa.XAResourceProxy
-  
- start() - Method in interface com.hazelcast.client.spi.ClientInvocationService
-  
- start() - Method in class com.hazelcast.client.spi.impl.ClientClusterServiceImpl
-  
- start() - Method in class com.hazelcast.client.spi.impl.ClientPartitionServiceImpl
-  
- start() - Method in class com.hazelcast.client.spi.impl.listener.ClientListenerServiceImpl
-  
- start() - Method in class com.hazelcast.client.spi.impl.listener.ClientNonSmartListenerService
-  
- start() - Method in class com.hazelcast.client.spi.impl.listener.ClientSmartListenerService
-  
- start(Xid, int) - Method in class com.hazelcast.client.txn.proxy.xa.XAResourceProxy
-  
- start(String[]) - Method in class com.hazelcast.console.ConsoleApp
-  
- start(Settings, Properties) - Method in class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
-  
- start() - Method in class com.hazelcast.internal.management.ManagementCenterService
-  
- start() - Method in class com.hazelcast.internal.metrics.renderers.CommaSeparatedKeyValueProbeRenderer
-  
- start() - Method in class com.hazelcast.internal.metrics.renderers.HumanFriendlyProbeRenderer
-  
- start() - Method in interface com.hazelcast.internal.metrics.renderers.ProbeRenderer
-  
- start() - Method in class com.hazelcast.internal.monitors.HealthMonitor
-  
- start() - Method in class com.hazelcast.internal.monitors.PerformanceMonitor
-  
- start(BootstrapContext) - Method in class com.hazelcast.jca.ResourceAdapterImpl
-  
- start() - Method in class com.hazelcast.jclouds.JCloudsDiscoveryStrategy
-  
- start() - Method in class com.hazelcast.map.impl.eviction.ExpirationManager
-  
- start() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreContext
-  
- start() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreManager
-  
- start() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindManager
-  
- start() - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughManager
-  
- start() - Method in interface com.hazelcast.nio.ConnectionManager
- 
Starts ConnectionManager, initializes its resources, starts threads, etc. 
- start() - Method in interface com.hazelcast.nio.tcp.IOThreadingModel
- 
Starts the IOThreadingModel. 
- start() - Method in class com.hazelcast.nio.tcp.nonblocking.iobalancer.IOBalancer
-  
- start() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingIOThreadingModel
-  
- start() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingSocketWriter
-  
- start() - Method in interface com.hazelcast.nio.tcp.SocketWriter
- 
Starts this SocketWriter. 
- start() - Method in class com.hazelcast.nio.tcp.spinning.SpinningIOThreadingModel
-  
- start() - Method in class com.hazelcast.nio.tcp.spinning.SpinningSocketWriter
-  
- start() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
- 
Starts this connection. 
- start() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- start(BundleContext) - Method in class com.hazelcast.osgi.impl.Activator
-  
- start() - Method in class com.hazelcast.quorum.impl.QuorumServiceImpl
-  
- start() - Method in class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
-  
- start() - Method in interface com.hazelcast.spi.discovery.DiscoveryStrategy
- 
The start method is used to initialize internal state and perform any kind of
 startup procedure like multicast socket creation. 
- start() - Method in class com.hazelcast.spi.discovery.impl.DefaultDiscoveryService
-  
- start() - Method in interface com.hazelcast.spi.discovery.integration.DiscoveryService
- 
The start method is called on system startup to implement simple
 lifecycle management. 
- start() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-  
- start() - Method in class com.hazelcast.spi.impl.operationexecutor.classic.ClassicOperationExecutor
-  
- start() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-  
- start() - Method in class com.hazelcast.spi.impl.servicemanager.impl.ServiceManagerImpl
-  
- start(Xid, int) - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
-  
- START_PROCESSING_OPERATION - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-  
- startAwaiting(Data, String, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-  
- startClusterMerge(Address) - Method in class com.hazelcast.cluster.impl.AbstractJoiner
-  
- startedAt - Variable in class com.hazelcast.internal.management.dto.SlowOperationInvocationDTO
-  
- startExecution(long) - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-  
- startExpirationTask() - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache
-  
- startInitialLoad(MapStoreContext, int) - Method in class com.hazelcast.map.impl.MapKeyLoader
-  
- startLoading(MapStoreContext, boolean) - Method in class com.hazelcast.map.impl.MapKeyLoader
-  
- startLoading() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-  
- startLoading() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
- 
Starts mapLoader 
- startPending() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-  
- startProcessing() - Method in class com.hazelcast.partition.MigrationInfo
-  
- StartProcessingJobOperation<K> - Class in com.hazelcast.mapreduce.impl.operation
- 
This operation is used to start the actual processing after all node prepared to execute the map reduce job 
- StartProcessingJobOperation() - Constructor for class com.hazelcast.mapreduce.impl.operation.StartProcessingJobOperation
-  
- StartProcessingJobOperation(String, String, Collection<K>, KeyPredicate<? super K>) - Constructor for class com.hazelcast.mapreduce.impl.operation.StartProcessingJobOperation
-  
- startSelectors() - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-  
- StartServer - Class in com.hazelcast.core.server
- 
Starts a Hazelcast server 
- startTasks(MappingPhase) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-  
- startTime - Variable in class com.hazelcast.client.impl.protocol.task.map.AbstractMapPutMessageTask
-  
- startTime - Variable in class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
-  
- startTime - Variable in class com.hazelcast.map.impl.client.MapPutRequest
-  
- startTime - Variable in class com.hazelcast.map.impl.client.MapRemoveRequest
-  
- STAT_NOT_AVAILABLE - Static variable in interface com.hazelcast.monitor.LocalInstanceStats
- 
Fill a stat value with this if it is not available 
- state - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-  
- stateChange(Address, int, JobPartitionState.State, JobProcessInformationImpl, JobTaskConfiguration) - Static method in class com.hazelcast.mapreduce.impl.MapReduceUtil
-  
- stateChanged(LifecycleEvent) - Method in interface com.hazelcast.core.LifecycleListener
- 
Called when instance's state changes. 
- stateChanged(LifecycleEvent) - Method in class com.hazelcast.web.listener.ClientLifecycleListener
-  
- stateChanged(LifecycleEvent) - Method in class com.hazelcast.web.listener.ServerLifecycleListener
-  
- StateMachine<T extends Enum<T>> - Class in com.hazelcast.util
- 
Simple state machine using an Enum as possible states. 
- StateMachine(T) - Constructor for class com.hazelcast.util.StateMachine
-  
- StaticLB - Class in com.hazelcast.client.util
- 
The StaticLB is a  LoadBalancer that always returns the same member. 
- StaticLB(Member) - Constructor for class com.hazelcast.client.util.StaticLB
-  
- statistics - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- statistics - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-  
- statistics - Variable in class com.hazelcast.map.impl.record.RecordInfo
-  
- statisticsAwareService - Variable in class com.hazelcast.map.impl.MapService
-  
- StatisticsAwareService - Interface in com.hazelcast.spi
- 
This interface is in BETA stage and is subject to change in upcoming releases. 
- Stats - Class in com.hazelcast.internal.ascii.memcache
-  
- Stats() - Constructor for class com.hazelcast.internal.ascii.memcache.Stats
-  
- StatsCommand - Class in com.hazelcast.internal.ascii.memcache
-  
- StatsCommand() - Constructor for class com.hazelcast.internal.ascii.memcache.StatsCommand
-  
- StatsCommandProcessor - Class in com.hazelcast.internal.ascii.memcache
-  
- StatsCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.memcache.StatsCommandProcessor
-  
- statsMap - Variable in class com.hazelcast.map.impl.LocalMapStatsProvider
-  
- StatsSupplier<T> - Interface in com.hazelcast.jmx.suppliers
- 
Interface used in MBeans for retrieving the Local Stats 
- stop() - Method in class com.hazelcast.client.console.ClientConsoleApp
-  
- stop() - Method in class com.hazelcast.client.spi.impl.ClientPartitionServiceImpl
-  
- stop() - Method in class com.hazelcast.cluster.impl.MulticastService
-  
- stop() - Method in class com.hazelcast.console.ConsoleApp
-  
- stop() - Method in class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
-  
- stop() - Method in class com.hazelcast.hibernate.local.CleanupService
-  
- stop() - Method in class com.hazelcast.internal.ascii.TextCommandServiceImpl
-  
- stop() - Method in class com.hazelcast.jca.ResourceAdapterImpl
-  
- stop() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreContext
-  
- stop() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreManager
-  
- stop() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindManager
-  
- stop() - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughManager
-  
- stop() - Method in interface com.hazelcast.nio.ConnectionManager
- 
Stops ConnectionManager, releases its resources, stops threads, etc. 
- stop() - Method in class com.hazelcast.nio.tcp.nonblocking.iobalancer.IOBalancer
-  
- stop() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-  
- stop(BundleContext) - Method in class com.hazelcast.osgi.impl.Activator
-  
- Storage<K,R> - Interface in com.hazelcast.map.impl.recordstore
- 
- storageRef - Variable in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-  
- StorageTypeAwareCacheMergePolicy - Interface in com.hazelcast.cache
- 
 Marker interface for indicating that key and value wrapped by
  CacheEntryView will be not converted to their original types. 
- store(Long, Data) - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
-  
- store(K, V) - Method in interface com.hazelcast.core.MapStore
- 
Stores the key-value pair. 
- store(K, V) - Method in class com.hazelcast.core.MapStoreAdapter
- 
Stores the key-value pair. 
- store(Long, T) - Method in interface com.hazelcast.core.QueueStore
- 
Stores the key-value pair. 
- store(Object, Object) - Method in class com.hazelcast.map.impl.MapStoreWrapper
-  
- store() - Method in class com.hazelcast.map.impl.record.EmptyRecordStatistics
-  
- store() - Method in interface com.hazelcast.map.impl.record.RecordStatistics
-  
- store() - Method in class com.hazelcast.map.impl.record.RecordStatisticsImpl
-  
- storeAll(Map<Long, Data>) - Method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
-  
- storeAll(Map<K, V>) - Method in interface com.hazelcast.core.MapStore
- 
Stores multiple entries. 
- storeAll(Map<K, V>) - Method in class com.hazelcast.core.MapStoreAdapter
- 
Stores multiple entries. 
- storeAll(Map<Long, T>) - Method in interface com.hazelcast.core.QueueStore
- 
Stores multiple entries. 
- storeAll(Map) - Method in class com.hazelcast.map.impl.MapStoreWrapper
-  
- STORED - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
-  
- StoreEvent<E> - Class in com.hazelcast.map.impl.mapstore.writebehind
- 
For internal usage only. 
- storeSequence(long) - Method in class com.hazelcast.topic.impl.reliable.ReliableMessageListenerAdapter
-  
- storeSequence(long) - Method in interface com.hazelcast.topic.ReliableMessageListener
- 
Informs the ReliableMessageListener that it should store the sequence. 
- StoreWorker - Class in com.hazelcast.map.impl.mapstore.writebehind
- 
Used to process store operations in another thread. 
- StoreWorker(MapStoreContext, WriteBehindProcessor) - Constructor for class com.hazelcast.map.impl.mapstore.writebehind.StoreWorker
-  
- StreamSerializer<T> - Interface in com.hazelcast.nio.serialization
- 
A base class for custom serialization. 
- STRING - Static variable in class com.hazelcast.client.impl.protocol.ResponseMessageConst
-  
- STRING_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
-  
- StringAndPartitionAwarePartitioningStrategy - Class in com.hazelcast.partition.strategy
-  
- StringPartitioningStrategy - Class in com.hazelcast.partition.strategy
-  
- StringPartitioningStrategy() - Constructor for class com.hazelcast.partition.strategy.StringPartitioningStrategy
-  
- stringToBytes(String) - Static method in class com.hazelcast.util.StringUtil
- 
Creates a byte array from a string. 
- StringUtil - Class in com.hazelcast.util
- 
Utility class for Strings. 
- StripedExecutor - Class in com.hazelcast.util.executor
- 
The StripedExecutor internally uses a stripe of queues and each queue has its own private worker-thread. 
- StripedExecutor(ILogger, String, ThreadGroup, int, int) - Constructor for class com.hazelcast.util.executor.StripedExecutor
-  
- StripedRunnable - Interface in com.hazelcast.util.executor
- 
Striped Runnable is used in StripedExecutor. 
- sub(int, int) - Method in class com.hazelcast.collection.impl.list.ListContainer
-  
- subList(int, int) - Method in class com.hazelcast.client.proxy.ClientListProxy
-  
- subList(int, int) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
-  
- subList(int, int) - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
-  
- submit(Callable<T>, MemberSelector) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submit(Runnable, MemberSelector, ExecutionCallback) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submit(Callable<T>, MemberSelector, ExecutionCallback<T>) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submit(Runnable) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submit(Runnable, T) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submit(Callable<T>) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submit(Runnable, ExecutionCallback<T>) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submit(Callable<T>, ExecutionCallback<T>) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submit(Runnable) - Method in interface com.hazelcast.client.spi.ClientExecutionService
-  
- submit(Callable<T>) - Method in interface com.hazelcast.client.spi.ClientExecutionService
-  
- submit(Runnable) - Method in class com.hazelcast.client.spi.impl.ClientExecutionServiceImpl
-  
- submit(Callable<T>) - Method in class com.hazelcast.client.spi.impl.ClientExecutionServiceImpl
-  
- submit(Callable<T>, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
- 
Submits a task to a randomly selected member and returns a Future
 representing that task. 
- submit(Runnable, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
- 
Submits a task to a random member. 
- submit(Runnable, MemberSelector, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
- 
Submits a task to randomly selected members. 
- submit(Callable<T>, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
- 
Submits a task to a random member. 
- submit(Callable<T>, MemberSelector, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
- 
Submits task to a randomly selected member. 
- submit(Callable<T>, MemberSelector) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submit(Runnable, MemberSelector, ExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submit(Callable<T>, MemberSelector, ExecutionCallback<T>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submit(Runnable) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submit(Runnable, T) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submit(Callable<T>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submit(Runnable, ExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submit(Callable<T>, ExecutionCallback<T>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submit() - Method in class com.hazelcast.mapreduce.impl.AbstractJob.MappingJobImpl
-  
- submit(Collator<Map.Entry<Key, List<Value>>, ValueOut>) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.MappingJobImpl
-  
- submit() - Method in class com.hazelcast.mapreduce.impl.AbstractJob.ReducingJobImpl
-  
- submit(Collator<Map.Entry<Key, List<Value>>, ValueOut>) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.ReducingJobImpl
-  
- submit() - Method in class com.hazelcast.mapreduce.impl.AbstractJob.ReducingSubmittableJobImpl
-  
- submit(Collator<Map.Entry<Key, Value>, ValueOut>) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.ReducingSubmittableJobImpl
-  
- submit(Collator) - Method in class com.hazelcast.mapreduce.impl.AbstractJob
-  
- submit() - Method in interface com.hazelcast.mapreduce.MappingJob
- 
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes. 
- submit(Collator<Map.Entry<KeyIn, List<ValueIn>>, ValueOut>) - Method in interface com.hazelcast.mapreduce.MappingJob
- 
Submits the task to Hazelcast, executes the defined mapper and reducer on all cluster nodes, and executes the
 collator before returning the final result. 
- submit() - Method in interface com.hazelcast.mapreduce.ReducingJob
- 
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes 
- submit(Collator<Map.Entry<KeyIn, List<ValueIn>>, ValueOut>) - Method in interface com.hazelcast.mapreduce.ReducingJob
- 
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes and executes the
 collator before returning the final result. 
- submit() - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
- 
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes. 
- submit(Collator<Map.Entry<KeyIn, ValueIn>, ValueOut>) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
- 
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes and executes the
 collator before returning the final result. 
- submit(String, Runnable) - Method in interface com.hazelcast.spi.ExecutionService
-  
- submit(String, Callable<T>) - Method in interface com.hazelcast.spi.ExecutionService
-  
- submit(String, Runnable) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-  
- submit(String, Callable<T>) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-  
- submit(Callable<T>) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-  
- submit(Runnable, T) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-  
- submit(Runnable) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-  
- submitInternal(Runnable) - Method in class com.hazelcast.client.spi.impl.ClientExecutionServiceImpl
-  
- submitToAllMembers(Callable<T>) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submitToAllMembers(Runnable, MultiExecutionCallback) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submitToAllMembers(Callable<T>, MultiExecutionCallback) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submitToAllMembers(Callable<T>) - Method in interface com.hazelcast.core.IExecutorService
- 
Submits task to all cluster members and returns a
 map of Member-Future pairs representing pending completion of the task on each member. 
- submitToAllMembers(Runnable, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
- 
Submits task to all the cluster members. 
- submitToAllMembers(Callable<T>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
- 
Submits task to all the cluster members. 
- submitToAllMembers(Callable<T>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submitToAllMembers(Runnable, MultiExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submitToAllMembers(Callable<T>, MultiExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submitToKey(K, EntryProcessor, ExecutionCallback) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- submitToKey(K, EntryProcessor) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- submitToKey(K, EntryProcessor, ExecutionCallback) - Method in interface com.hazelcast.core.IMap
- 
Applies the user defined EntryProcessor to the entry mapped by the key with
 specified ExecutionCallback to listen event status and returns immediately. 
- submitToKey(K, EntryProcessor) - Method in interface com.hazelcast.core.IMap
- 
Applies the user defined EntryProcessor to the entry mapped by the key. 
- submitToKey(K, EntryProcessor, ExecutionCallback) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- submitToKey(K, EntryProcessor) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- submitToKeyInternal(Data, EntryProcessor, ExecutionCallback) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- submitToKeyInternal(Data, EntryProcessor) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- submitToKeyInternal(Data, EntryProcessor) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- submitToKeyInternal(Data, EntryProcessor, ExecutionCallback) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-  
- submitToKeyOwner(Callable<T>, Object) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submitToKeyOwner(Runnable, Object, ExecutionCallback) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submitToKeyOwner(Callable<T>, Object, ExecutionCallback<T>) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submitToKeyOwner(Callable<T>, Object) - Method in interface com.hazelcast.core.IExecutorService
- 
Submits a task to the owner of the specified key and returns a Future
 representing that task. 
- submitToKeyOwner(Runnable, Object, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
- 
Submits a task to the owner of the specified key. 
- submitToKeyOwner(Callable<T>, Object, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
- 
Submits task to the owner of the specified key. 
- submitToKeyOwner(Callable<T>, Object) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submitToKeyOwner(Runnable, Object, ExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submitToKeyOwner(Callable<T>, Object, ExecutionCallback<T>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submitToMember(Callable<T>, Member) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submitToMember(Runnable, Member, ExecutionCallback) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submitToMember(Callable<T>, Member, ExecutionCallback<T>) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submitToMember(Callable<T>, Member) - Method in interface com.hazelcast.core.IExecutorService
- 
Submits a task to the specified member and returns a Future
 representing that task. 
- submitToMember(Runnable, Member, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
- 
Submits a task to the specified member. 
- submitToMember(Callable<T>, Member, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
- 
Submits a task to the specified member. 
- submitToMember(Callable<T>, Member) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submitToMember(Runnable, Member, ExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submitToMember(Callable<T>, Member, ExecutionCallback<T>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submitToMembers(Callable<T>, Collection<Member>) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submitToMembers(Callable<T>, MemberSelector) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submitToMembers(Runnable, Collection<Member>, MultiExecutionCallback) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submitToMembers(Callable<T>, Collection<Member>, MultiExecutionCallback) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submitToMembers(Runnable, MemberSelector, MultiExecutionCallback) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submitToMembers(Callable<T>, MemberSelector, MultiExecutionCallback) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-  
- submitToMembers(Callable<T>, Collection<Member>) - Method in interface com.hazelcast.core.IExecutorService
- 
Submits a task to given members and returns
 map of Member-Future pairs representing pending completion of the task on each member 
- submitToMembers(Callable<T>, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
- 
Submits a task to selected members and returns a
 map of Member-Future pairs representing pending completion of the task on each member. 
- submitToMembers(Runnable, Collection<Member>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
- 
Submits a task to the specified members. 
- submitToMembers(Runnable, MemberSelector, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
- 
Submits task to the selected members. 
- submitToMembers(Callable<T>, Collection<Member>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
- 
Submits a task to the specified members. 
- submitToMembers(Callable<T>, MemberSelector, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
- 
Submits task to the selected members. 
- submitToMembers(Callable<T>, MemberSelector) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submitToMembers(Runnable, MemberSelector, MultiExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submitToMembers(Callable<T>, MemberSelector, MultiExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submitToMembers(Callable<T>, Collection<Member>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submitToMembers(Runnable, Collection<Member>, MultiExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- submitToMembers(Callable<T>, Collection<Member>, MultiExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- SUCCESS - Static variable in class com.hazelcast.internal.management.request.ChangeWanStateRequest
- 
- success - Variable in class com.hazelcast.partition.impl.BaseMigrationOperation
-  
- SUCCESS_RESULT - Static variable in class com.hazelcast.internal.management.request.ForceStartNodeRequest
- 
Result sent within response when force start is triggered successfully 
- successful - Variable in class com.hazelcast.map.impl.operation.RemoveOperation
-  
- SuffixModifierUtils - Class in com.hazelcast.query.impl.getters
- 
Convenient utilities to parse attribute suffix modifiers from attributes. 
- Supplier<KeyIn,ValueIn,ValueOut> - Class in com.hazelcast.mapreduce.aggregation
- 
The Supplier interface is used to supply values from input data structures like
  IMap or  MultiMap to an
 aggregation. 
- Supplier() - Constructor for class com.hazelcast.mapreduce.aggregation.Supplier
-  
- Supplier<T> - Interface in com.hazelcast.util.function
- 
Represents a supplier of results. 
- SUPPLIER_CONSUMING_MAPPER - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-  
- SwCounter - Class in com.hazelcast.util.counters
- 
A  Counter that is made to be used by a single writing thread. 
- SymmetricEncryptionConfig - Class in com.hazelcast.config
- 
Contains configuration for symmetric encryption 
- SymmetricEncryptionConfig() - Constructor for class com.hazelcast.config.SymmetricEncryptionConfig
-  
- SYNC_DELAY_MS - Static variable in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- SYNC_FREQUENCY - Static variable in class com.hazelcast.executor.impl.ExecutorServiceProxy
-  
- SYNC_WAITING - Static variable in interface com.hazelcast.partition.InternalPartition
- 
Indicates that a replica index is waiting for a backup sync 
- SyncReplicatedMapDataOperation<K,V> - Class in com.hazelcast.replicatedmap.impl.operation
- 
Carries set of replicated map records for a partition from one node to another 
- SyncReplicatedMapDataOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.SyncReplicatedMapDataOperation
-  
- SyncReplicatedMapDataOperation(String, Set<RecordMigrationInfo>, long) - Constructor for class com.hazelcast.replicatedmap.impl.operation.SyncReplicatedMapDataOperation
-  
- SYSTEM_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
- 
Name of the system executor. 
- systemLogger - Variable in class com.hazelcast.instance.DefaultNodeExtension
-  
- validate(T) - Method in interface com.hazelcast.config.properties.ValueValidator
- 
Validates the given value according to the defined validation logic
 and throws a ValidationException if configuration does not meet the
 requirements or logical errors are spotted. 
- validate(Integer) - Method in class com.hazelcast.jclouds.JCloudsProperties.PortValueValidator
-  
- validateConfiguredKeyType(Class<K>, K) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
- 
Validates the key with key type. 
- validateConfiguredTypes(CacheConfig, K) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
- 
Validates that the configured key matches the provided key. 
- validateConfiguredTypes(CacheConfig, K, V) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
- 
Validates the configured key and value types matches the provided key, value types. 
- validateConfiguredTypes(CacheConfig, K, V, V) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
- 
Validates the configured key and value types matches the provided key, value types. 
- validateConfiguredValueType(Class<V>, V) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
- 
Validates the value with value type. 
- validateJoinMessage(JoinMessage) - Method in class com.hazelcast.cluster.impl.ClusterJoinManager
-  
- validateJoinRequest() - Method in class com.hazelcast.instance.DefaultNodeExtension
-  
- validateJoinRequest() - Method in interface com.hazelcast.instance.NodeExtension
- 
Called before a new node is joining to cluster,
 executed if node is the master node before join event. 
- validateNotNull(K) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
- 
Validates that a key is not null. 
- validateNotNull(K, V) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
- 
Validates that key, value pair are both not null. 
- validateNotNull(K, V, V) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
- 
Validates that key and multi values are not null. 
- validateNotNull(Set<? extends K>) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
- 
Validates that none of the keys are null in set. 
- validateNotNull(Map<? extends K, ? extends V>) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
- 
This validator ensures that no key or value is null in the provided map. 
- validateResults(Map<Integer, Object>) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
- 
Cache clear response validator, loop on results to validate that no exception exists on the result map. 
- validatesTarget() - Method in class com.hazelcast.cluster.impl.operations.PostJoinOperation
-  
- validatesTarget() - Method in class com.hazelcast.partition.impl.BaseMigrationOperation
-  
- validatesTarget() - Method in class com.hazelcast.partition.impl.CheckReplicaVersion
-  
- validatesTarget() - Method in class com.hazelcast.partition.impl.ReplicaSyncRequest
-  
- validatesTarget() - Method in class com.hazelcast.partition.impl.ReplicaSyncResponse
-  
- validatesTarget() - Method in class com.hazelcast.partition.impl.ReplicaSyncRetryResponse
-  
- validatesTarget() - Method in class com.hazelcast.replicatedmap.impl.operation.EvictionOperation
-  
- validatesTarget() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
-  
- validatesTarget() - Method in class com.hazelcast.spi.Operation
-  
- ValidationException - Exception in com.hazelcast.config.properties
- 
This exception is thrown from  ValueValidator
 implementations whenever the validation has not succeed for any reason. 
- ValidationException(String) - Constructor for exception com.hazelcast.config.properties.ValidationException
-  
- ValidationException(String, Throwable) - Constructor for exception com.hazelcast.config.properties.ValidationException
-  
- ValidationException(Throwable) - Constructor for exception com.hazelcast.config.properties.ValidationException
-  
- validator() - Method in interface com.hazelcast.config.properties.PropertyDefinition
- 
Returns an optional validator to validate a value before finalizing the
 configuration. 
- validator() - Method in class com.hazelcast.config.properties.SimplePropertyDefinition
-  
- value - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-  
- value - Variable in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-  
- value - Variable in class com.hazelcast.cache.impl.record.CacheObjectRecord
-  
- value - Variable in class com.hazelcast.collection.impl.collection.client.CollectionAddRequest
-  
- value - Variable in class com.hazelcast.collection.impl.collection.CollectionItem
-  
- value - Variable in class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
-  
- value - Variable in class com.hazelcast.collection.impl.txncollection.client.TxnCollectionRequest
-  
- value - Variable in class com.hazelcast.core.EntryEvent
-  
- VALUE - Static variable in class com.hazelcast.hibernate.serialization.HibernateDataSerializerHook
-  
- Value - Class in com.hazelcast.hibernate.serialization
- 
A value within a region cache 
- Value() - Constructor for class com.hazelcast.hibernate.serialization.Value
-  
- Value(Object, long, Object) - Constructor for class com.hazelcast.hibernate.serialization.Value
-  
- value - Variable in class com.hazelcast.map.impl.client.MapPutRequest
-  
- value - Variable in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-  
- value - Variable in class com.hazelcast.query.impl.predicates.EqualPredicate
-  
- value - Variable in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
-  
- value() - Method in enum com.hazelcast.query.QueryConstants
-  
- value - Variable in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
-  
- value() - Method in class com.hazelcast.util.collection.Long2LongHashMap.LongLongCursor
-  
- value - Variable in class com.hazelcast.util.ConcurrentReferenceHashMap.SimpleEntry
-  
- value - Variable in class com.hazelcast.util.MutableInteger
-  
- value - Variable in class com.hazelcast.util.MutableLong
-  
- VALUE_SPACE - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
-  
- ValueCallback<T> - Class in com.hazelcast.query.extractor
- 
- ValueCallback() - Constructor for class com.hazelcast.query.extractor.ValueCallback
-  
- ValueCollectionFactory - Class in com.hazelcast.multimap.impl
- 
Multi-map values are backed by collections which are created by static factory methods in this class. 
- ValueCollector<T> - Class in com.hazelcast.query.extractor
- 
- ValueCollector() - Constructor for class com.hazelcast.query.extractor.ValueCollector
-  
- valueCount(K) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-  
- valueCount(K) - Method in class com.hazelcast.client.proxy.txn.ClientTxnMultiMapProxy
-  
- valueCount(K) - Method in class com.hazelcast.client.txn.proxy.ClientTxnMultiMapProxy
-  
- valueCount(K) - Method in interface com.hazelcast.core.BaseMultiMap
- 
Returns the number of values matching the given key in the multimap. 
- valueCount(K) - Method in interface com.hazelcast.core.MultiMap
- 
Returns the number of values that match the given key in the multimap. 
- valueCount(K) - Method in interface com.hazelcast.core.TransactionalMultiMap
- 
Returns the number of values matching the given key in the multimap. 
- valueCount(K) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-  
- valueCount(K) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
-  
- valueCountInternal(Data) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-  
- ValueExtractor<T,A> - Class in com.hazelcast.query.extractor
- 
Common superclass for all extractors that enable the user to define custom attributes and extract their values. 
- ValueExtractor() - Constructor for class com.hazelcast.query.extractor.ValueExtractor
-  
- valueList - Variable in class com.hazelcast.collection.impl.collection.client.CollectionAddAllRequest
-  
- valueList - Variable in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
-  
- valueLoaded - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-  
- valueMap - Variable in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllBackupOperation
-  
- valueMap - Variable in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
-  
- valueMap - Variable in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-  
- valueOf(String) - Static method in enum com.hazelcast.cache.BuiltInCacheMergePolicies
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.cache.impl.CacheEntryProcessorEntry.State
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.cache.impl.CacheEntryViews.CacheEntryViewType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.cache.impl.CacheEventType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.cache.impl.maxsize.impl.CompositeMaxSizeChecker.CompositionOperator
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.cache.impl.nearcache.NearCacheType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.client.ClientEventType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.client.config.ClientProperty
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.client.impl.protocol.AuthenticationStatus
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.client.map.impl.nearcache.ClientNearCacheType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.cluster.ClusterState
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.cluster.MemberAttributeOperationType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.config.AbstractConfigBuilder.ConfigType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.config.CacheDeserializedValues
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.config.CacheEvictionConfig.CacheMaxSizePolicy
- 
Deprecated. Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.config.EvictionConfig.MaxSizePolicy
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.config.EvictionPolicy
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.config.InMemoryFormat
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.config.MapStoreConfig.InitialLoadMode
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.config.MaxSizeConfig.MaxSizePolicy
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.config.MultiMapConfig.ValueCollectionType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.config.NativeMemoryConfig.MemoryAllocatorType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.config.NearCacheConfig.LocalUpdatePolicy
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.config.PartitionGroupConfig.MemberGroupType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.config.PermissionConfig.PermissionType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.config.properties.PropertyTypeConverter
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.config.WanAcknowledgeType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.config.WANQueueFullBehavior
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.core.ClientType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.core.DistributedObjectEvent.EventType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.core.EntryEventType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.core.ItemEventType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.core.LifecycleEvent.LifecycleState
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.core.MigrationEvent.MigrationStatus
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.instance.GroupProperty
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.instance.NodeState
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.internal.ascii.TextCommandConstants.TextCommandType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.internal.eviction.EvictionPolicyType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.internal.eviction.EvictionStrategyType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.internal.metrics.ProbeLevel
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.internal.monitors.HealthMonitorLevel
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.map.impl.client.AbstractTxnMapRequest.TxnMapRequestType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.mapreduce.impl.operation.RequestPartitionResult.ResultState
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.mapreduce.JobPartitionState.State
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.mapreduce.TopologyChangedStrategy
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.memory.MemoryUnit
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.multimap.impl.operations.MultiMapOperationFactory.OperationFactoryType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.nio.ConnectionType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.nio.serialization.FieldType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.nio.tcp.nonblocking.SelectorMode
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.partition.impl.InternalPartitionServiceState
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.partition.MigrationEndpoint
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.query.impl.AttributeType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.query.impl.ComparisonType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.query.impl.predicates.QueryOptimizerFactory.Type
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.query.QueryConstants
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.quorum.QuorumType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.ringbuffer.OverflowPolicy
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.spi.discovery.integration.DiscoveryMode
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.spi.ExceptionAction
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.topic.TopicOverloadPolicy
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.transaction.impl.Transaction.State
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.util.ConcurrentReferenceHashMap.Option
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.util.ConcurrentReferenceHashMap.ReferenceType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.util.executor.ExecutorType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum com.hazelcast.util.IterationType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(long) - Static method in class com.hazelcast.util.MutableLong
-  
- valueOf(String) - Static method in enum com.hazelcast.util.scheduler.ScheduleType
- 
Returns the enum constant of this type with the specified name. 
- ValueReader - Class in com.hazelcast.query.extractor
- 
Enables reading the value of the attribute specified by the path 
- ValueReader() - Constructor for class com.hazelcast.query.extractor.ValueReader
-  
- ValueReadingException - Exception in com.hazelcast.query.extractor
- 
Exception thrown if there is any checked or unchecked exception caught in the value reading in  ValueReader
- ValueReadingException(String, Throwable) - Constructor for exception com.hazelcast.query.extractor.ValueReadingException
-  
- values() - Static method in enum com.hazelcast.cache.BuiltInCacheMergePolicies
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.cache.impl.CacheEntryProcessorEntry.State
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.cache.impl.CacheEntryViews.CacheEntryViewType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.cache.impl.CacheEventType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.cache.impl.maxsize.impl.CompositeMaxSizeChecker.CompositionOperator
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.cache.impl.nearcache.NearCacheType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.client.ClientEventType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.client.config.ClientProperty
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.client.impl.protocol.AuthenticationStatus
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.client.map.impl.nearcache.ClientNearCacheType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- values(Predicate) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-  
- values() - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
-  
- values() - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-  
- values(Comparator<V>) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
-  
- values() - Method in class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-  
- values(Predicate) - Method in class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-  
- values() - Method in class com.hazelcast.client.txn.proxy.ClientTxnMapProxy
-  
- values(Predicate) - Method in class com.hazelcast.client.txn.proxy.ClientTxnMapProxy
-  
- values() - Static method in enum com.hazelcast.cluster.ClusterState
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.cluster.MemberAttributeOperationType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.config.AbstractConfigBuilder.ConfigType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.config.CacheDeserializedValues
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.config.CacheEvictionConfig.CacheMaxSizePolicy
- 
Deprecated. Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.config.EvictionConfig.MaxSizePolicy
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.config.EvictionPolicy
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.config.InMemoryFormat
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.config.MapStoreConfig.InitialLoadMode
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.config.MaxSizeConfig.MaxSizePolicy
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.config.MultiMapConfig.ValueCollectionType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.config.NativeMemoryConfig.MemoryAllocatorType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.config.NearCacheConfig.LocalUpdatePolicy
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.config.PartitionGroupConfig.MemberGroupType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.config.PermissionConfig.PermissionType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.config.properties.PropertyTypeConverter
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.config.WanAcknowledgeType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.config.WANQueueFullBehavior
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.core.ClientType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.core.DistributedObjectEvent.EventType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.core.EntryEventType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Method in interface com.hazelcast.core.IMap
- 
Returns a collection clone of the values contained in this map. 
- values(Predicate) - Method in interface com.hazelcast.core.IMap
- 
Queries the map based on the specified predicate and
 returns the values of matching entries. 
- values() - Static method in enum com.hazelcast.core.ItemEventType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.core.LifecycleEvent.LifecycleState
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.core.MigrationEvent.MigrationStatus
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Method in interface com.hazelcast.core.MultiMap
- 
Returns the collection of values in the multimap. 
- values() - Method in interface com.hazelcast.core.ReplicatedMap
- 
Returns a lazy  Collection view of the values contained in this map. 
 A LazyCollection is optimized for querying speed (preventing eager deserialization
 and hashing on HashSet insertion) and does  NOT provide all operations. 
- values(Comparator<V>) - Method in interface com.hazelcast.core.ReplicatedMap
- 
Returns an eagerly populated  Collection view of the values contained in this map. 
- values() - Method in interface com.hazelcast.core.TransactionalMap
- 
- values(Predicate) - Method in interface com.hazelcast.core.TransactionalMap
- 
- values() - Static method in enum com.hazelcast.instance.GroupProperty
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.instance.NodeState
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.internal.ascii.TextCommandConstants.TextCommandType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.internal.eviction.EvictionPolicyType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.internal.eviction.EvictionStrategyType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.internal.metrics.ProbeLevel
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.internal.monitors.HealthMonitorLevel
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values(String) - Method in class com.hazelcast.jmx.MapMBean
-  
- values() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-  
- values() - Static method in enum com.hazelcast.map.impl.client.AbstractTxnMapRequest.TxnMapRequestType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- VALUES - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-  
- values() - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- values(Predicate) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-  
- values() - Method in interface com.hazelcast.map.impl.recordstore.Storage
-  
- values() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-  
- values(Predicate) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-  
- values() - Method in interface com.hazelcast.map.QueryCache
-  
- values(Predicate) - Method in interface com.hazelcast.map.QueryCache
-  
- values() - Static method in enum com.hazelcast.mapreduce.impl.operation.RequestPartitionResult.ResultState
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.mapreduce.JobPartitionState.State
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.mapreduce.TopologyChangedStrategy
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.memory.MemoryUnit
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-  
- VALUES - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-  
- VALUES - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-  
- values() - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-  
- values() - Static method in enum com.hazelcast.multimap.impl.operations.MultiMapOperationFactory.OperationFactoryType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.nio.ConnectionType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.nio.serialization.FieldType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.nio.tcp.nonblocking.SelectorMode
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.partition.impl.InternalPartitionServiceState
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.partition.MigrationEndpoint
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.query.impl.AttributeType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.query.impl.ComparisonType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.query.impl.predicates.QueryOptimizerFactory.Type
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.query.QueryConstants
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.quorum.QuorumType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- VALUES - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-  
- values(boolean) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-  
- values(Comparator) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-  
- values() - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
-  
- values(boolean) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- values(Comparator) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-  
- values() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-  
- values(Comparator<V>) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-  
- values() - Static method in enum com.hazelcast.ringbuffer.OverflowPolicy
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.spi.discovery.integration.DiscoveryMode
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.spi.ExceptionAction
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.topic.TopicOverloadPolicy
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.transaction.impl.Transaction.State
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
- values() - Method in class com.hazelcast.util.collection.Long2LongHashMap
- values() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
- values() - Static method in enum com.hazelcast.util.ConcurrentReferenceHashMap.Option
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.util.ConcurrentReferenceHashMap.ReferenceType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
- 
Returns a  Collection view of the values contained in this map. 
- values() - Static method in enum com.hazelcast.util.executor.ExecutorType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.util.IterationType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum com.hazelcast.util.scheduler.ScheduleType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- VALUES_COLLECTION - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-  
- valuesInternal() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-  
- ValuesOperation - Class in com.hazelcast.multimap.impl.operations
-  
- ValuesOperation() - Constructor for class com.hazelcast.multimap.impl.operations.ValuesOperation
-  
- ValuesOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.ValuesOperation
-  
- ValuesOperation - Class in com.hazelcast.replicatedmap.impl.operation
-  
- ValuesOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ValuesOperation
-  
- ValuesOperation(String) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ValuesOperation
-  
- ValuesRequest - Class in com.hazelcast.multimap.impl.client
-  
- ValuesRequest() - Constructor for class com.hazelcast.multimap.impl.client.ValuesRequest
-  
- ValuesRequest(String) - Constructor for class com.hazelcast.multimap.impl.client.ValuesRequest
-  
- valueToData(Object) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-  
- valueToData(Object) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-  
- valueToData(V) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- valueToRecord(V) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-  
- valueToRecord(V) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.NearCacheDataRecordStore
-  
- valueToRecord(V) - Method in class com.hazelcast.cache.impl.nearcache.impl.store.NearCacheObjectRecordStore
-  
- ValueValidator<T extends Comparable<T>> - Interface in com.hazelcast.config.properties
- 
This interface defines a certain validation logic implementation
 to test if a given value is expected to be correct or not. 
- verify() - Method in class com.hazelcast.config.JoinConfig
- 
Verifies this JoinConfig is valid. 
- VERSION - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
- 
Current protocol version 
- version - Variable in class com.hazelcast.hibernate.serialization.Expirable
-  
- version - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-  
- version - Variable in class com.hazelcast.map.impl.record.AbstractRecord
-  
- version - Variable in class com.hazelcast.map.impl.record.RecordInfo
-  
- VERSION - Static variable in class com.hazelcast.nio.Packet
-  
- VERSION_1 - Static variable in interface com.hazelcast.internal.serialization.SerializationService
-  
- VersionAwareMapMergePolicy - Class in com.hazelcast.hibernate
- 
A merge policy implementation to handle split brain remerges based on the timestamps stored in
  the values. 
- VersionAwareMapMergePolicy() - Constructor for class com.hazelcast.hibernate.VersionAwareMapMergePolicy
-  
- VersionCommand - Class in com.hazelcast.internal.ascii.memcache
-  
- VersionCommand(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.internal.ascii.memcache.VersionCommand
-  
- VersionCommandProcessor - Class in com.hazelcast.internal.ascii.memcache
-  
- VersionCommandProcessor(TextCommandServiceImpl) - Constructor for class com.hazelcast.internal.ascii.memcache.VersionCommandProcessor
-  
- versionComparator - Variable in class com.hazelcast.hibernate.access.AbstractAccessDelegate
-  
- versionComparator - Variable in class com.hazelcast.hibernate.local.LocalRegionCache
-  
- VersionedPortable - Interface in com.hazelcast.nio.serialization
- 
VersionedPortable is an extension to  Portable
 to support per class version instead of a global serialization version. 
- VersionedValue - Class in com.hazelcast.map.impl.tx
- 
Wrapper for  Data value objects with version information. 
- VersionedValue(Data, long) - Constructor for class com.hazelcast.map.impl.tx.VersionedValue
-  
- VersionedValue() - Constructor for class com.hazelcast.map.impl.tx.VersionedValue
-  
- VersionResponsePair - Class in com.hazelcast.replicatedmap.impl.operation
- 
Contains response and partition version for update operations on replicated map. 
- VersionResponsePair() - Constructor for class com.hazelcast.replicatedmap.impl.operation.VersionResponsePair
-  
- VersionResponsePair(Object, long) - Constructor for class com.hazelcast.replicatedmap.impl.operation.VersionResponsePair
-  
- visit(AndPredicate, Indexes) - Method in class com.hazelcast.query.impl.predicates.AbstractVisitor
-  
- visit(OrPredicate, Indexes) - Method in class com.hazelcast.query.impl.predicates.AbstractVisitor
-  
- visit(NotPredicate, Indexes) - Method in class com.hazelcast.query.impl.predicates.AbstractVisitor
-  
- visit(AndPredicate, Indexes) - Method in class com.hazelcast.query.impl.predicates.BetweenVisitor
-  
- visit(AndPredicate, Indexes) - Method in class com.hazelcast.query.impl.predicates.FlatteningVisitor
-  
- visit(OrPredicate, Indexes) - Method in class com.hazelcast.query.impl.predicates.FlatteningVisitor
-  
- visit(NotPredicate, Indexes) - Method in class com.hazelcast.query.impl.predicates.FlatteningVisitor
-  
- visit(OrPredicate, Indexes) - Method in class com.hazelcast.query.impl.predicates.OrToInVisitor
-  
- visit(AndPredicate, Indexes) - Method in interface com.hazelcast.query.impl.predicates.Visitor
-  
- visit(OrPredicate, Indexes) - Method in interface com.hazelcast.query.impl.predicates.Visitor
-  
- visit(NotPredicate, Indexes) - Method in interface com.hazelcast.query.impl.predicates.Visitor
-  
- VisitablePredicate - Interface in com.hazelcast.query
- 
Predicates which can be visited by optimizer. 
- Visitor - Interface in com.hazelcast.query.impl.predicates
- 
Visitor can inspect internal state of a node,
 but it's not allowed to mutate its internal state. 
- VisitorUtils - Class in com.hazelcast.query.impl.predicates
-  
- VOID - Static variable in class com.hazelcast.client.impl.protocol.ResponseMessageConst
-