- 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
-
- 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
-
Abstract cache request to handle a completion id registration.
- 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, IOSelector) - 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
-
- 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
-
- 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.cache.impl.eviction.impl.evaluator
-
- AbstractEvictionPolicyEvaluator() - Constructor for class com.hazelcast.cache.impl.eviction.impl.evaluator.AbstractEvictionPolicyEvaluator
-
- AbstractEvictionStrategy<A,E extends Evictable,S extends EvictableStore<A,E>> - Class in com.hazelcast.cache.impl.eviction.impl.strategy
-
- AbstractEvictionStrategy() - Constructor for class com.hazelcast.cache.impl.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
-
- 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 RegionFactory
implementations
- 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 CachingProvider
implementation providing shared functionality to server and client caching
providers.
- AbstractHazelcastCachingProvider() - Constructor for class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- 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.
- AbstractInvocationMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
-
- AbstractInvocationMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractInvocationMessageTask
-
- AbstractIOSelector - Class in com.hazelcast.nio.tcp
-
- AbstractIOSelector(ThreadGroup, String, ILogger, IOSelectorOutOfMemoryHandler) - Constructor for class com.hazelcast.nio.tcp.AbstractIOSelector
-
- 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) - Constructor for class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-
- AbstractMapAddEntryListenerRequest(String, Data, boolean) - 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
-
- AbstractMapOperation - Class in com.hazelcast.map.impl.operation
-
- AbstractMapOperation() - Constructor for class com.hazelcast.map.impl.operation.AbstractMapOperation
-
- AbstractMapOperation(String) - Constructor for class com.hazelcast.map.impl.operation.AbstractMapOperation
-
- 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(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
-
- 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
-
- 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
-
- 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
-
- AbstractReplicatedMapOperation - Class in com.hazelcast.replicatedmap.impl.operation
-
Base class for replicated map remote operations
- AbstractReplicatedMapOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
-
- AbstractReplicatedRecordStore<K,V> - Class in com.hazelcast.replicatedmap.impl.record
-
- AbstractReplicatedRecordStore(String, NodeEngine, ReplicatedMapService) - 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
-
- AbstractSelectionHandler - Class in com.hazelcast.nio.tcp
-
- AbstractSelectionHandler(TcpIpConnection, IOSelector, int) - Constructor for class com.hazelcast.nio.tcp.AbstractSelectionHandler
-
- 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, TransactionSupport, 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
-
- 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
-
- AbstractXmlConfigHelper.IterableNodeList - Class in com.hazelcast.config
-
Iterator for NodeList
- AbstractXmlConfigHelper.IterableNodeList(Node) - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper.IterableNodeList
-
- AbstractXmlConfigHelper.IterableNodeList(NodeList) - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper.IterableNodeList
-
- AbstractXmlConfigHelper.IterableNodeList(Node, short) - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper.IterableNodeList
-
- AbstractXmlConfigHelper.IterableNodeList(NodeList, short) - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper.IterableNodeList
-
- 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) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- access() - Method in class com.hazelcast.map.impl.NearCacheRecord
-
- access() - Method in class com.hazelcast.map.impl.record.RecordStatistics
-
- access() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- ACCESS_HIT_NOT_AVAILABLE - Static variable in interface com.hazelcast.cache.impl.record.CacheRecord
-
- 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
-
- accumulate(CacheStatisticsImpl) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
Simple CacheStatistics adder.
- acquire(String, int) - Method in interface com.hazelcast.client.impl.protocol.template.SemaphoreCodecTemplate
-
- 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
-
- Activator - Class in com.hazelcast.internal.osgi
-
Hazelcast OSGi bundle activator
initializes script Engines
- Activator() - Constructor for class com.hazelcast.internal.osgi.Activator
-
- activeConnectionCount - Variable in class com.hazelcast.internal.management.dto.ConnectionManagerDTO
-
- add(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.ListCodecTemplate
-
- add(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.SetCodecTemplate
-
- add(String, String, long, Data) - Method in interface com.hazelcast.client.impl.protocol.template.TransactionalListCodecTemplate
-
- add(String, String, long, Data) - Method in interface com.hazelcast.client.impl.protocol.template.TransactionalSetCodecTemplate
-
- 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.ClientQueueProxy
-
- 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(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.MapEntrySet
-
- add(Data, Data) - Method in class com.hazelcast.map.impl.MapEntrySet
-
- 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(long) - Method in interface com.hazelcast.map.impl.SizeEstimator
-
- add(QueryableEntry) - Method in class com.hazelcast.query.impl.MultiResultSet
-
- 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(T, long) - Method in class com.hazelcast.util.ItemCounter
-
Add delta to the item
- add(QueryResultEntry) - Method in class com.hazelcast.util.QueryResultSet
-
- add(Object) - Method in class com.hazelcast.util.QueryResultSet
-
- add(Map.Entry) - Method in class com.hazelcast.util.SortedQueryResultSet
-
- 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_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_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_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(String, List<Data>) - Method in interface com.hazelcast.client.impl.protocol.template.ListCodecTemplate
-
- addAll(String, Collection<Data>) - Method in interface com.hazelcast.client.impl.protocol.template.QueueCodecTemplate
-
- addAll(String, List<Data>) - Method in interface com.hazelcast.client.impl.protocol.template.SetCodecTemplate
-
- 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.ClientQueueProxy
-
- 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.QueryResult
-
- addAll(Data[]) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-
- 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
-
- addAllWithIndex(String, int, List<Data>) - Method in interface com.hazelcast.client.impl.protocol.template.ListCodecTemplate
-
- addAndGet(String, long) - Method in interface com.hazelcast.client.impl.protocol.template.AtomicLongCodecTemplate
-
- 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.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
-
- 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
.
- 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.nio.serialization.DefaultSerializationServiceBuilder
-
- addClassDefinition(ClassDefinition) - Method in interface com.hazelcast.nio.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
-
- 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
-
- 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.nio.serialization.DefaultSerializationServiceBuilder
-
- addDataSerializableFactory(int, DataSerializableFactory) - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
-
- addDataSerializableFactoryClass(int, String) - Method in class com.hazelcast.config.SerializationConfig
-
- addDataSerializableFactoryClass(int, Class<? extends DataSerializableFactory>) - Method in class com.hazelcast.config.SerializationConfig
-
- addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- addDistributedObjectListener() - Method in interface com.hazelcast.client.impl.protocol.template.ClientMessageTemplate
-
- 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
-
- 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(String) - Method in interface com.hazelcast.client.impl.protocol.template.CacheCodecTemplate
-
- addEntryListener(String, boolean) - Method in interface com.hazelcast.client.impl.protocol.template.MapCodecTemplate
-
- addEntryListener(String, boolean) - Method in interface com.hazelcast.client.impl.protocol.template.MultiMapCodecTemplate
-
- addEntryListener(String) - Method in interface com.hazelcast.client.impl.protocol.template.ReplicatedMapCodecTemplate
-
- 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, Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- addEntryListener(EntryListener, Predicate, Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- addEntryListener(EntryListener, Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- addEntryListener(EntryListener, Predicate, Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- 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
-
- addEntryListenerToKey(String, Data, boolean) - Method in interface com.hazelcast.client.impl.protocol.template.MapCodecTemplate
-
- addEntryListenerToKey(String, Data, boolean) - Method in interface com.hazelcast.client.impl.protocol.template.MultiMapCodecTemplate
-
- addEntryListenerToKey(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.ReplicatedMapCodecTemplate
-
- addEntryListenerToKeyWithPredicate(String, Data, Data, boolean) - Method in interface com.hazelcast.client.impl.protocol.template.MapCodecTemplate
-
- addEntryListenerToKeyWithPredicate(String, Data, Data) - Method in interface com.hazelcast.client.impl.protocol.template.ReplicatedMapCodecTemplate
-
- addEntryListenerWithPredicate(String, Data, boolean) - Method in interface com.hazelcast.client.impl.protocol.template.MapCodecTemplate
-
- addEntryListenerWithPredicate(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.ReplicatedMapCodecTemplate
-
- addEventData(CacheEventData) - Method in class com.hazelcast.cache.impl.CacheEventSet
-
Helper method for adding multiple CacheEventData into this Set
- addEventListener(Object, EventFilter, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
-
- addEventListener(EventListener, EventFilter, String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- addExecutorConfig(ExecutorConfig) - Method in class com.hazelcast.config.Config
-
Adds a new ExecutorConfig by name
- 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, String, boolean) - Method in interface com.hazelcast.client.impl.protocol.template.MapCodecTemplate
-
- 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(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.MapCodecTemplate
-
- 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, MapInterceptor) - Method in class com.hazelcast.map.impl.MapContainer
-
- 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) - Method in class com.hazelcast.cache.impl.CacheService
-
- addInvalidationListener(String) - Method in interface com.hazelcast.client.impl.protocol.template.CacheCodecTemplate
-
- 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.ClientQueueProxy
-
- addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-
- addItemListener(String, ItemListener, 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
-
- addJvmId(String) - Method in class com.hazelcast.web.SessionState
-
- 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, boolean) - Method in interface com.hazelcast.client.impl.protocol.template.ListCodecTemplate
-
- addListener(String, boolean) - Method in interface com.hazelcast.client.impl.protocol.template.QueueCodecTemplate
-
- addListener(String, boolean) - Method in interface com.hazelcast.client.impl.protocol.template.SetCodecTemplate
-
- 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
-
- 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
-
- 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
-
- addMapConfig(MapConfig) - Method in class com.hazelcast.config.Config
-
- 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
-
- addMemberInfo(MemberInfo, Map<Address, Integer>, int) - Method in class com.hazelcast.partition.PartitionRuntimeState
-
- 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.ClusterProxy
-
- 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.
- AddMembershipListenerRequest - Class in com.hazelcast.cluster.client
-
- AddMembershipListenerRequest() - Constructor for class com.hazelcast.cluster.client.AddMembershipListenerRequest
-
- addMessageListener(String) - Method in interface com.hazelcast.client.impl.protocol.template.TopicCodecTemplate
-
- 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) - 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
- addNearCacheEntryListener(String, boolean) - Method in interface com.hazelcast.client.impl.protocol.template.MapCodecTemplate
-
- addNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-
- addOperation(Operation) - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLog
-
- 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.IndexService
-
- addOutboundPort(int) - Method in class com.hazelcast.config.NetworkConfig
-
- addOutboundPortDefinition(String) - Method in class com.hazelcast.config.NetworkConfig
-
- addOwnershipMapping(String, String) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- addPartitionLostListener() - Method in interface com.hazelcast.client.impl.protocol.template.ClientMessageTemplate
-
- addPartitionLostListener(String) - Method in interface com.hazelcast.client.impl.protocol.template.MapCodecTemplate
-
- 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.nio.serialization.DefaultSerializationServiceBuilder
-
- addPortableFactory(int, PortableFactory) - Method in interface com.hazelcast.nio.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, 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 queryCacheConfig
to this MapConfig
.
- 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(ReliableTopicConfig) - Method in class com.hazelcast.config.Config
-
- addRemoveTimeNanos(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
Increments the remove time accumulator.
- addReplicatedMapConfig(ReplicatedMapConfig) - Method in class com.hazelcast.config.Config
-
- 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
-
- AddressCodec - Class in com.hazelcast.client.impl.protocol.codec
-
- 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.MultiResultSet
-
- addRingbuffer(String, RingbufferContainer) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-
- addRingBufferConfig(RingbufferConfig) - Method in class com.hazelcast.config.Config
-
- 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.AbstractIOSelector
-
- addTask(Runnable) - Method in interface com.hazelcast.nio.tcp.IOSelector
-
- addTaskAndWakeup(Runnable) - Method in class com.hazelcast.nio.tcp.AbstractIOSelector
-
- addTaskAndWakeup(Runnable) - Method in interface com.hazelcast.nio.tcp.IOSelector
-
Adds a task to be executed by the IOSelector and wakes up the IOSelector 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.
- addTransactionLog(TransactionLog) - Method in class com.hazelcast.transaction.impl.TransactionImpl
-
- addTransactionLog(TransactionLog) - Method in interface com.hazelcast.transaction.impl.TransactionSupport
-
- 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.
- addUTFField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addWanReplicationConfig(WanReplicationConfig) - Method in class com.hazelcast.config.Config
-
- addWithIndex(String, int, Data) - Method in interface com.hazelcast.client.impl.protocol.template.ListCodecTemplate
-
- advance() - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-
- 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
-
- 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.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.AbstractMapOperation
-
- 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.MergeOperation
-
- 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.TryPutOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.WanOriginatedDeleteOperation
-
- 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.AbstractReplicatedMapOperation
-
- 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.transaction.impl.BeginTxBackupOperation
-
- afterRun() - Method in class com.hazelcast.transaction.impl.BroadcastTxRollbackOperation
-
- afterRun() - Method in class com.hazelcast.transaction.impl.PurgeTxBackupOperation
-
- afterRun() - Method in class com.hazelcast.transaction.impl.ReplicateTxOperation
-
- afterRun() - Method in class com.hazelcast.transaction.impl.RollbackTxBackupOperation
-
- afterRun() - Method in class com.hazelcast.transaction.impl.xa.ClearRemoteTransactionBackupOperation
-
- afterRun() - Method in class com.hazelcast.transaction.impl.xa.ClearRemoteTransactionOperation
-
- afterRun() - Method in class com.hazelcast.transaction.impl.xa.CollectRemoteTransactionsOperation
-
- afterRun() - Method in class com.hazelcast.transaction.impl.xa.FinalizeRemoteTransactionBackupOperation
-
- afterRun() - Method in class com.hazelcast.transaction.impl.xa.FinalizeRemoteTransactionOperation
-
- afterRun() - Method in class com.hazelcast.transaction.impl.xa.PutRemoteTransactionBackupOperation
-
- afterRun() - Method in class com.hazelcast.transaction.impl.xa.PutRemoteTransactionOperation
-
- 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(Node) - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- afterStart(Node) - 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.nio.serialization.FactoryIdHelper
-
- AGGREGATIONS_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.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.
- 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
PropertyExtractor
s transformation to the
input data.
- allDone(Collection<Future>) - Static method in class com.hazelcast.util.FutureUtil
-
Check if all futures are done
- allowUnsafe - Variable in class com.hazelcast.nio.serialization.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(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.AtomicLongCodecTemplate
-
- alter(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.AtomicReferenceCodecTemplate
-
- 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(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.AtomicLongCodecTemplate
-
- alterAndGet(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.AtomicReferenceCodecTemplate
-
- 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(Predicate) - Method in class com.hazelcast.query.PredicateBuilder
-
- and(Predicate...) - Static method in class com.hazelcast.query.Predicates
-
- 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<V>) - Method in class com.hazelcast.client.spi.impl.ClientInvocationFuture
-
- andThen(ExecutionCallback<V>, 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.CompletableFutureTask
-
- andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.util.executor.CompletableFutureTask
-
- 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<Data>) - Method in class com.hazelcast.client.spi.impl.ClientInvocationFuture
-
- andThenInternal(ExecutionCallback<Data>) - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-
- answerMasterQuestion(JoinMessage) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- 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.
- appendStackTrace(File) - Static method in class com.hazelcast.util.DebugUtil
-
Appends the stacktrace of the current thread to a file.
- appendToken(StringBuilder, StringBuilder) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- appendWithNewLine(File, String) - Static method in class com.hazelcast.util.DebugUtil
-
Appends text to a file.
- apply(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.AtomicLongCodecTemplate
-
- apply(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.AtomicReferenceCodecTemplate
-
- 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.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.Predicates.AndPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.BetweenPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.EqualPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.GreaterLessPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.InPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.LikePredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.NotEqualPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.NotPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.OrPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.RegexPredicate
-
- 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.
- applyAndIncrementVectorClock(VectorClockTimestamp, Member) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- applyChanges() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-
Provides a similar functionality as committing a transaction.
- 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
-
- applyVectorClock(VectorClockTimestamp) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- array() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- ArrayDataSerializableFactory - Class in com.hazelcast.nio.serialization
-
- ArrayDataSerializableFactory(ConstructorFunction<Integer, IdentifiedDataSerializable>[]) - Constructor for class com.hazelcast.nio.serialization.ArrayDataSerializableFactory
-
- ArrayListSerializerHook - Class in com.hazelcast.nio.serialization.serializers
-
This class is the auto registered serializer hook for a
ArrayList
.
- ArrayListSerializerHook() - Constructor for class com.hazelcast.nio.serialization.serializers.ArrayListSerializerHook
-
- ArrayListSerializerHook.ArrayListStreamSerializer - Class in com.hazelcast.nio.serialization.serializers
-
- ArrayListSerializerHook.ArrayListStreamSerializer() - Constructor for class com.hazelcast.nio.serialization.serializers.ArrayListSerializerHook.ArrayListStreamSerializer
-
- ArrayPortableFactory - Class in com.hazelcast.nio.serialization
-
- ArrayPortableFactory(ConstructorFunction<Integer, Portable>[]) - Constructor for class com.hazelcast.nio.serialization.ArrayPortableFactory
-
- asCompletableFuture(Future<V>) - Method in interface com.hazelcast.spi.ExecutionService
-
- asCompletableFuture(Future<V>) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-
- 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
-
- 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.
- 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
-
- asyncInvokeOnTarget(String, Operation, Address, ExecutionCallback<V>) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-
- asyncInvokeOnTarget(String, Operation, Address, 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.
- 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.nio.serialization.FactoryIdHelper
-
- ATOMIC_LONG_NAME - Static variable in class com.hazelcast.concurrent.idgen.IdGeneratorService
-
- ATOMIC_LONG_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- ATOMIC_LONG_TEMPLATE_ID - Static variable in class com.hazelcast.client.impl.protocol.template.TemplateConstants
-
- ATOMIC_REFERENCE_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- ATOMIC_REFERENCE_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- ATOMIC_REFERENCE_TEMPLATE_ID - Static variable in class com.hazelcast.client.impl.protocol.template.TemplateConstants
-
- 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
-
- AtomicLongCodecTemplate - Interface in com.hazelcast.client.impl.protocol.template
-
- 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
-
- AtomicReferenceCodecTemplate - Interface in com.hazelcast.client.impl.protocol.template
-
- 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
-
- attribute - Variable in class com.hazelcast.query.Predicates.AbstractPredicate
-
- attribute - Variable in class com.hazelcast.query.Predicates.LikePredicate
-
- 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.ResponseMessageConst
-
- authentication(String, String, String, String, boolean) - Method in interface com.hazelcast.client.impl.protocol.template.ClientMessageTemplate
-
- Authentication(Address, String, String) - Method in interface com.hazelcast.client.impl.protocol.template.ResponseTemplate
-
- 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
-
- authenticationCustom(Data, String, String, boolean) - Method in interface com.hazelcast.client.impl.protocol.template.ClientMessageTemplate
-
- 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
-
- 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
-
- AUTO_TYPE_ARRAY_LIST - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- AUTO_TYPE_JOB_PARTITION_STATE - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- AUTO_TYPE_JOB_PARTITION_STATE_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- AUTO_TYPE_LINKED_LIST - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- available() - Method in class com.hazelcast.nio.serialization.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(String) - Method in interface com.hazelcast.client.impl.protocol.template.SemaphoreCodecTemplate
-
- 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(String, long, long, String) - Method in interface com.hazelcast.client.impl.protocol.template.ConditionCodecTemplate
-
- await(String, long) - Method in interface com.hazelcast.client.impl.protocol.template.CountdownLatchCodecTemplate
-
- 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.InvocationRegistry
-
- 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.
- 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(int, Set<CacheEventData>, int) - Method in interface com.hazelcast.client.impl.protocol.template.EventResponseTemplate
-
- 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.nio.serialization.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_INVALIDATION_MESSAGE_BATCH_ENABLED - Variable in class com.hazelcast.instance.GroupProperties
-
- CACHE_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDS - Variable in class com.hazelcast.instance.GroupProperties
-
- CACHE_INVALIDATION_MESSAGE_BATCH_SIZE - Variable in class com.hazelcast.instance.GroupProperties
-
- 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_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- 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
-
- 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
-
- CacheBatchInvalidation(String, List<Data>, List<String>) - Method in interface com.hazelcast.client.impl.protocol.template.EventResponseTemplate
-
- 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
-
- cacheBatchInvalidationMessageSenderInProgress - Variable in class com.hazelcast.cache.impl.CacheService
-
- cacheBatchInvalidationMessageSenderScheduler - Variable in class com.hazelcast.cache.impl.CacheService
-
- 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
-
- CacheCodecTemplate - Interface in com.hazelcast.client.impl.protocol.template
-
- CacheConcurrentHashMap<K,V> - Class in com.hazelcast.util
-
ConcurrentHashMap to extend iterator capability
- CacheConcurrentHashMap(int) - Constructor for class com.hazelcast.util.CacheConcurrentHashMap
-
- CacheConcurrentHashMap(int, float, int, ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType, EnumSet<ConcurrentReferenceHashMap.Option>) - Constructor for class com.hazelcast.util.CacheConcurrentHashMap
-
- 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
-
- 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
-
- 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
-
- 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
-
- CacheEntry<K,V> - Class in com.hazelcast.cache.impl
-
Simple Cache.Entry
implementation for wrapping a "key,value" pair.
- CacheEntry(K, V) - Constructor for class com.hazelcast.cache.impl.CacheEntry
-
- 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
-
- CacheEntryListenerProvider<K,V> - Interface in com.hazelcast.cache.impl
-
Provides underlying (wrapped) CacheEntryListener
instance.
- CacheEntryProcessorEntry<K,V,R extends CacheRecord> - Class in com.hazelcast.cache.impl
-
This class is an implementation of MutableEntry
which is provided into
EntryProcessor.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 EntryProcessorResult
wraps 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
-
- 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.
- CacheEventDataCodec - Class in com.hazelcast.client.impl.protocol.codec
-
- 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
-
- 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
-
- CacheInvalidation(String, Data, String) - Method in interface com.hazelcast.client.impl.protocol.template.EventResponseTemplate
-
- CacheInvalidationListener - Class in com.hazelcast.cache.impl.client
-
- CacheInvalidationListener(ClientEndpoint, int) - 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
-
- cacheIterator() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-
- 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
-
- 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
-
- 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
- CachePartitionSegment - Class in com.hazelcast.cache.impl
-
Cache Partition Segment
- 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
-
- 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
-
- 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
-
Operation implementation for
com.hazelcast.cache.impl.ICacheRecordStore#put(Data, Object, ExpiryPolicy, String)
and
com.hazelcast.cache.impl.ICacheRecordStore#getAndPut(Data, Object, ExpiryPolicy, String)
.
- 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) - Constructor for class com.hazelcast.cache.impl.record.CacheRecordHashMap
-
- CacheRecordHashMap(int, float, int, ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType, EnumSet<ConcurrentReferenceHashMap.Option>) - 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
-
- 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, 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, 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
-
- 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 - 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
-
- CacheService.CacheBatchInvalidationMessageSender - Class in com.hazelcast.cache.impl
-
- CacheService.CacheBatchInvalidationMessageSender() - Constructor for class com.hazelcast.cache.impl.CacheService.CacheBatchInvalidationMessageSender
-
- 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
-
- 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() - 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
- cacheWriter - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- cachingProvider - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- calculateByteArrayDataSize(byte[]) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-
- calculateDataSize(Address) - Static method in class com.hazelcast.client.impl.protocol.codec.AddressCodec
-
- calculateDataSize(CacheEventData) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheEventDataCodec
-
- calculateDataSize(DistributedObjectInfo) - Static method in class com.hazelcast.client.impl.protocol.codec.DistributedObjectInfoCodec
-
- calculateDataSize(SimpleEntryView<Data, Data>) - Static method in class com.hazelcast.client.impl.protocol.codec.EntryViewCodec
-
- calculateDataSize(JobPartitionState) - Static method in class com.hazelcast.client.impl.protocol.codec.JobPartitionStateCodec
-
- calculateDataSize(MemberAttributeChange) - Static method in class com.hazelcast.client.impl.protocol.codec.MemberAttributeChangeCodec
-
- calculateDataSize(Member) - Static method in class com.hazelcast.client.impl.protocol.codec.MemberCodec
-
- calculateDataSize(Xid) - Static method in class com.hazelcast.client.impl.protocol.codec.XIDCodec
-
- calculateDataSize(String, String, String, String) - Static method in class com.hazelcast.client.impl.protocol.parameters.ExceptionResultParameters
-
sample data size estimation
- calculateDataSize(Data) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-
- 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.nio.serialization.SerializationServiceImpl
-
- calculateStringDataSize(String) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-
- 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.CacheRemoveEntryListenerRequest
-
- call() - Method in class com.hazelcast.cache.impl.client.CacheRemoveInvalidationListenerRequest
-
- call() - Method in class com.hazelcast.client.impl.client.AuthenticationRequest
-
- call() - Method in class com.hazelcast.client.impl.client.ClientCreateRequest
-
- call() - Method in class com.hazelcast.client.impl.client.ClientDestroyRequest
-
- call() - Method in class com.hazelcast.client.impl.client.DistributedObjectListenerRequest
-
- 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.client.RemoveDistributedObjectListenerRequest
-
- 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.AbstractTransactionalMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
-
- 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.CacheRemoveEntryListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.CreateProxyMessageTask
-
- 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.GetDistributedObjectMessageTask
-
- 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.list.ListRemoveListenerMessageTask
-
- 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.map.MapRemoveEntryListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemovePartitionLostListenerMessageTask
-
- 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.multimap.MultiMapRemoveEntryListenerMessageTask
-
- 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.queue.QueueRemoveListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.RegisterMembershipListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistrubtedObjectListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapClearMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsKeyMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapContainsValueMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapEntrySetMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapGetMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapIsEmptyMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapKeySetMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutAllMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapPutMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveEntryListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapRemoveMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapSizeMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.ReplicatedMapValuesMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.set.SetRemoveListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicAddMessageListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicRemoveMessageListenerMessageTask
-
- 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.collection.client.CollectionRemoveListenerRequest
-
- call() - Method in class com.hazelcast.collection.impl.queue.client.AddListenerRequest
-
- call() - Method in class com.hazelcast.collection.impl.queue.client.RemoveListenerRequest
-
- 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.client.MapRemoveEntryListenerRequest
-
- call() - Method in class com.hazelcast.map.impl.client.MapRemovePartitionLostListenerRequest
-
- call() - Method in class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-
- call() - Method in class com.hazelcast.multimap.impl.client.RemoveEntryListenerRequest
-
- call() - Method in class com.hazelcast.partition.client.AddPartitionLostListenerRequest
-
- call() - Method in class com.hazelcast.partition.client.GetPartitionsRequest
-
- call() - Method in class com.hazelcast.partition.client.RemovePartitionLostListenerRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapClearRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsKeyRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsValueRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapEntrySetRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapGetRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapIsEmptyRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapKeySetRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutTtlRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapSizeRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapValuesRequest
-
- call() - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-
- call() - Method in class com.hazelcast.topic.impl.client.RemoveMessageListenerRequest
-
- 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
-
- 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, int, String, 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.spi.impl.operationservice.impl
-
Responsible for generating callIds.
- CallIdSequence() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.CallIdSequence
-
- 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.DefaultRecordStore
-
- canAcquireLock(Data, String, long) - Method in interface com.hazelcast.map.impl.RecordStore
-
- canAcquireLock(Data, String, long) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- cancel(String, String) - Method in interface com.hazelcast.client.impl.protocol.template.MapReduceCodecTemplate
-
- cancel(boolean) - Method in class com.hazelcast.client.spi.impl.ClientInvocationFuture
-
- cancel(boolean) - Method in class com.hazelcast.client.util.ClientCancellableDelegatingFuture
-
- cancel(boolean) - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-
- 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.mapreduce.impl.task.TrackableJobFuture
-
- 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
-
- cancelEviction(ObjectNamespace, Data) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- 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_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
-
- cancelOnAddress(String, String, int, boolean) - Method in interface com.hazelcast.client.impl.protocol.template.ExecutorServiceCodecTemplate
-
- cancelOnPartition(String, int, boolean) - Method in interface com.hazelcast.client.impl.protocol.template.ExecutorServiceCodecTemplate
-
- cancelPartitionState() - Method in class com.hazelcast.mapreduce.impl.task.JobProcessInformationImpl
-
- 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.Int2ObjectHashMap
-
Get the total capacity for the map to which the load factor with be a fraction of.
- 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.nio.DynamicByteBuffer
-
- capacity() - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
-
- capacity() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
-
Returns the capacity of this Ringbuffer.
- capitalizeFirstLetter(String) - Static method in class com.hazelcast.client.protocol.generator.CodeGenerationUtils
-
- causeClassName - Variable in class com.hazelcast.client.impl.protocol.parameters.ExceptionResultParameters
-
- cd - Variable in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- CDL_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- CDL_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- changeSessionId() - Method in class com.hazelcast.web.WebFilter.RequestWrapper
-
- 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_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.VersionCheck
-
- 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.
- checkAuthorization(String, String, Address) - Method in class com.hazelcast.wan.impl.WanNoDelayReplication
-
- 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.nio.serialization.DefaultSerializationServiceBuilder
-
- checkEvictable(MapContainer, int) - Method in class com.hazelcast.map.impl.eviction.MaxSizeChecker
-
- checkFalse(boolean, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests whether the supplied expression is false
.
- checkFalse(boolean, String) - Static method in class com.hazelcast.util.ValidationUtil
-
Tests whether the supplied expression is false
.
- checkFullyProcessed(JobProcessInformation) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- checkHasNext(Iterator<T>, String) - Static method in class com.hazelcast.util.ValidationUtil
-
Check if iterator has next element.
- checkHasText(String, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests if a string contains text.
- checkIfLoaded() - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- checkIfLoaded() - Method in interface com.hazelcast.map.impl.RecordStore
-
- checkIfManagerNotClosed() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- checkIndexNotNegative(int) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-
- 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.
- checkInstanceOf(Class, E, String) - Static method in class com.hazelcast.util.ValidationUtil
-
Tests whether the supplied object is an instance of the supplied class type.
- checkJoinInfo(Address) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- 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.
- checkNotInstanceOf(Class, E, String) - Static method in class com.hazelcast.util.ValidationUtil
-
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, String) - Static method in class com.hazelcast.util.ValidationUtil
-
Tests if an argument is not null.
- 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.
- 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
-
- checkState(boolean, String) - Static method in class com.hazelcast.util.ValidationUtil
-
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(String) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- checkTrue(boolean, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests whether the supplied expression is true
.
- 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.
- CipherHelper - Class in com.hazelcast.nio
-
- 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
-
- classDefinitions - Variable in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- ClassicOperationExecutor - Class in com.hazelcast.spi.impl.operationexecutor.classic
-
- ClassicOperationExecutor(GroupProperties, LoggingService, Address, OperationRunnerFactory, ResponsePacketHandler, HazelcastThreadGroup, NodeExtension) - Constructor for class com.hazelcast.spi.impl.operationexecutor.classic.ClassicOperationExecutor
-
- classLoader - Variable in class com.hazelcast.nio.serialization.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.client.impl.protocol.parameters.ExceptionResultParameters
-
- 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.
- cleanConnectionResources(ClientConnection) - Method in interface com.hazelcast.client.spi.ClientInvocationService
-
- CleanerRegistrator - Interface in com.hazelcast.replicatedmap.impl
-
This interface is used to give
ReplicatedRecordStore
implementations
a chance to register themself to being cleaned up from expired entries
- cleanNodeName(Node) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- cleanNodeName(String) - 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.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(String) - Method in interface com.hazelcast.client.impl.protocol.template.AtomicReferenceCodecTemplate
-
- clear(String) - Method in interface com.hazelcast.client.impl.protocol.template.CacheCodecTemplate
-
- clear(String) - Method in interface com.hazelcast.client.impl.protocol.template.ListCodecTemplate
-
- clear(String) - Method in interface com.hazelcast.client.impl.protocol.template.MapCodecTemplate
-
- clear(String) - Method in interface com.hazelcast.client.impl.protocol.template.MultiMapCodecTemplate
-
- clear(String) - Method in interface com.hazelcast.client.impl.protocol.template.QueueCodecTemplate
-
- clear(String) - Method in interface com.hazelcast.client.impl.protocol.template.ReplicatedMapCodecTemplate
-
- clear(String) - Method in interface com.hazelcast.client.impl.protocol.template.SetCodecTemplate
-
- clear() - Method in class com.hazelcast.client.impl.protocol.util.Int2ObjectHashMap
- clear() - Method in class com.hazelcast.client.impl.protocol.util.Int2ObjectHashMap.KeySet
-
- clear() - Method in class com.hazelcast.client.nearcache.ClientHeapNearCache
-
- clear() - Method in interface com.hazelcast.client.nearcache.ClientNearCache
-
- 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.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.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.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() - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- 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() - Method in class com.hazelcast.map.impl.NearCache
-
- clear() - Method in class com.hazelcast.map.impl.NearCacheProvider
-
- 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 interface com.hazelcast.map.impl.RecordStore
-
- 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.BufferObjectDataOutput
-
- clear() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- 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(boolean, boolean) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- clear(boolean, boolean) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- clear() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- clear() - Method in class com.hazelcast.spring.cache.HazelcastCache
-
- 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_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.IndexService
-
- 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(String) - Method in class com.hazelcast.map.impl.NearCacheProvider
-
- 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
-
- 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
-
- clearPartition() - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- clearPartition() - Method in interface com.hazelcast.map.impl.RecordStore
-
- 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.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() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- clearRecords() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-
- clearRemote(Xid) - Method in interface com.hazelcast.client.impl.protocol.template.XATransactionalCodecTemplate
-
- ClearRemoteTransactionBackupOperation - Class in com.hazelcast.transaction.impl.xa
-
- ClearRemoteTransactionBackupOperation() - Constructor for class com.hazelcast.transaction.impl.xa.ClearRemoteTransactionBackupOperation
-
- ClearRemoteTransactionBackupOperation(Data) - Constructor for class com.hazelcast.transaction.impl.xa.ClearRemoteTransactionBackupOperation
-
- ClearRemoteTransactionOperation - Class in com.hazelcast.transaction.impl.xa
-
- ClearRemoteTransactionOperation() - Constructor for class com.hazelcast.transaction.impl.xa.ClearRemoteTransactionOperation
-
- ClearRemoteTransactionOperation(Data) - Constructor for class com.hazelcast.transaction.impl.xa.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
-
- 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 - 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.nio.serialization.FactoryIdHelper
-
- CLIENT_ENGINE_THREAD_COUNT - Variable in class com.hazelcast.instance.GroupProperties
-
- 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_HEARTBEAT_TIMEOUT_SECONDS - Variable in class com.hazelcast.instance.GroupProperties
-
- 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.nio.serialization.FactoryIdHelper
-
- CLIENT_RESPONSE - Static variable in class com.hazelcast.client.impl.ClientDataSerializerHook
-
ClientResponse Class ID
- CLIENT_TEMPLATE_ID - Static variable in class com.hazelcast.client.impl.protocol.template.TemplateConstants
-
- CLIENT_TXN_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- 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
-
- ClientCancellableDelegatingFuture<V> - Class in com.hazelcast.client.util
-
A DelegatingFuture that can cancel a Runnable/Callable that is executed by an
IExecutorService
.
- ClientCancellableDelegatingFuture(ICompletableFuture, ClientContext, String, Address, int, V) - 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) - 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, IOSelector, IOSelector, int, SocketChannelWrapper) - 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
-
- 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) - 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
-
- ClientDelegatingFuture(ClientInvocationFuture, SerializationService, V) - Constructor for class com.hazelcast.client.util.ClientDelegatingFuture
-
- ClientDelegatingFuture(ClientInvocationFuture, SerializationService) - 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
-
- ClientEngineMBean - Class in com.hazelcast.jmx
-
- ClientEngineMBean(HazelcastInstance, ClientEngine, ManagementService) - Constructor for class com.hazelcast.jmx.ClientEngineMBean
-
- 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.
- ClientExecutionService - Interface in com.hazelcast.client.spi
-
- ClientExecutionServiceImpl - Class in com.hazelcast.client.spi.impl
-
- ClientExecutionServiceImpl(String, ThreadGroup, ClassLoader, 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.nearcache
-
- ClientHeapNearCache(String, ClientContext, NearCacheConfig) - Constructor for class com.hazelcast.client.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(HazelcastClientInstanceImpl, EventHandler, ClientRequest) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocation
-
- ClientInvocation(HazelcastClientInstanceImpl, EventHandler, ClientRequest, int) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocation
-
- ClientInvocation(HazelcastClientInstanceImpl, EventHandler, ClientRequest, Address) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocation
-
- ClientInvocation(HazelcastClientInstanceImpl, EventHandler, ClientRequest, Connection) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocation
-
- ClientInvocation(HazelcastClientInstanceImpl, ClientRequest) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocation
-
- ClientInvocation(HazelcastClientInstanceImpl, ClientRequest, int) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocation
-
- ClientInvocation(HazelcastClientInstanceImpl, ClientRequest, Address) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocation
-
- ClientInvocation(HazelcastClientInstanceImpl, ClientRequest, Connection) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocation
-
- ClientInvocationFuture<V> - Class in com.hazelcast.client.spi.impl
-
- ClientInvocationFuture(ClientInvocation, HazelcastClientInstanceImpl, ClientRequest, EventHandler) - 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
-
- 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
-
- ClientListenerServiceImpl(HazelcastClientInstanceImpl, int, int) - Constructor for class com.hazelcast.client.spi.impl.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
-
- 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
-
- 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
- ClientMessageTemplate - Interface in com.hazelcast.client.impl.protocol.template
-
- ClientMultiMapProxy<K,V> - Class in com.hazelcast.client.proxy
-
- ClientMultiMapProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientMultiMapProxy
-
- ClientNearCache<K,V> - Interface in com.hazelcast.client.nearcache
-
ClientNearCache
- ClientNearCacheType - Enum in com.hazelcast.client.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
-
- ClientNonSmartInvocationServiceImpl - Class in com.hazelcast.client.spi.impl
-
- ClientNonSmartInvocationServiceImpl(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.spi.impl.ClientNonSmartInvocationServiceImpl
-
- ClientOutOfMemoryHandler - Class in com.hazelcast.client
-
To clear resources of the client upon OutOfMemory
- ClientOutOfMemoryHandler() - Constructor for class com.hazelcast.client.ClientOutOfMemoryHandler
-
- ClientOutSelectorImpl - Class in com.hazelcast.client.connection.nio
-
- ClientOutSelectorImpl(ThreadGroup, String, ILogger, IOSelectorOutOfMemoryHandler) - Constructor for class com.hazelcast.client.connection.nio.ClientOutSelectorImpl
-
- 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
-
Client Properties
- ClientProperties(ClientConfig) - Constructor for class com.hazelcast.client.config.ClientProperties
-
- ClientProperties.ClientProperty - Class in com.hazelcast.client.config
-
A single client property.
- ClientProtocolBuffer - Interface in com.hazelcast.client.impl.protocol.util
-
Interface for buffer to be used in client protocol.
- 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, IOSelector, 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
-
- ClientReplicatedMapAddEntryListenerRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapAddEntryListenerRequest(String, Predicate, Object) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
-
- 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, Object) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsKeyRequest
-
- ClientReplicatedMapContainsValueRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapContainsValueRequest(String, Object) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsValueRequest
-
- ClientReplicatedMapEntrySetRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapEntrySetRequest(String) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapEntrySetRequest
-
- ClientReplicatedMapGetRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapGetRequest(String, Object) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapGetRequest
-
- ClientReplicatedMapIsEmptyRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapIsEmptyRequest(String) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapIsEmptyRequest
-
- ClientReplicatedMapKeySetRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapKeySetRequest(String) - 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(String, ReplicatedMapEntrySet) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-
- ClientReplicatedMapPutTtlRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapPutTtlRequest(String, Object, Object, 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, String) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-
- ClientReplicatedMapRemoveRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapRemoveRequest(String, Object) - 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) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapSizeRequest
-
- ClientReplicatedMapValuesRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapValuesRequest(String) - 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, int, boolean) - Constructor for class com.hazelcast.client.impl.client.ClientResponse
-
- 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
-
- ClientService - Interface in com.hazelcast.core
-
ClientService allows you to query connected
Client
s and
attach/detach
ClientListener
s 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
-
- 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, IOSelector, 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
-
- cloneWithoutValues() - Method in class com.hazelcast.map.impl.EntryEventData
-
- 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() - 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() - 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.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.DynamicByteBuffer
-
- close() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- close() - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
-
- close() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-
- close() - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-
Closes socket channel.
- 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.
- closeableListeners - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-
- closeConnection() - Method in class com.hazelcast.nio.ascii.SocketTextReader
-
- 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.
- 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
-
- 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, String) - Constructor for class com.hazelcast.web.ClusteredSessionService
-
Instantiates a new Clustered session service.
- ClusterListenerSupport - Class in com.hazelcast.client.spi.impl
-
- ClusterListenerSupport(HazelcastClientInstanceImpl) - 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
-
- ClusterProxy - Class in com.hazelcast.cluster.impl
-
- ClusterProxy(ClusterServiceImpl) - Constructor for class com.hazelcast.cluster.impl.ClusterProxy
-
- ClusterService - Interface in com.hazelcast.cluster
-
A service responsible for member related functionality.
- clusterService - Variable in class com.hazelcast.instance.Node
-
- ClusterServiceImpl - Class in com.hazelcast.cluster.impl
-
- ClusterServiceImpl(Node) - Constructor for class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- 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
-
- CodecCodeGenerator - Class in com.hazelcast.client.protocol.generator
-
- CodecCodeGenerator() - Constructor for class com.hazelcast.client.protocol.generator.CodecCodeGenerator
-
- CodecModel - Class in com.hazelcast.client.protocol.generator
-
- CodecModel(TypeElement, ExecutableElement, ExecutableElement, List<ExecutableElement>, boolean, Lang) - Constructor for class com.hazelcast.client.protocol.generator.CodecModel
-
- CodecModel.EventModel - Class in com.hazelcast.client.protocol.generator
-
- CodecModel.EventModel() - Constructor for class com.hazelcast.client.protocol.generator.CodecModel.EventModel
-
- CodecModel.ParameterModel - Class in com.hazelcast.client.protocol.generator
-
- CodecModel.ParameterModel() - Constructor for class com.hazelcast.client.protocol.generator.CodecModel.ParameterModel
-
- CodeGenerationUtils - Class in com.hazelcast.client.protocol.generator
-
- CodeGeneratorMessageTaskFactory - Class in com.hazelcast.client.protocol.generator
-
- CodeGeneratorMessageTaskFactory() - Constructor for class com.hazelcast.client.protocol.generator.CodeGeneratorMessageTaskFactory
-
- 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.nio.serialization.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.nio.serialization.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(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, 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(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
-
- CollectionTransactionLog - Class in com.hazelcast.collection.impl.txncollection
-
- CollectionTransactionLog() - Constructor for class com.hazelcast.collection.impl.txncollection.CollectionTransactionLog
-
- CollectionTransactionLog(long, String, int, String, String, Operation) - Constructor for class com.hazelcast.collection.impl.txncollection.CollectionTransactionLog
-
- 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
-
- CollectRemoteTransactionsOperation() - Constructor for class com.hazelcast.transaction.impl.xa.CollectRemoteTransactionsOperation
-
- CollectRemoteTransactionsOperationFactory - Class in com.hazelcast.transaction.impl.xa
-
- CollectRemoteTransactionsOperationFactory() - Constructor for class com.hazelcast.transaction.impl.xa.CollectRemoteTransactionsOperationFactory
-
- collectTransactions() - Method in interface com.hazelcast.client.impl.protocol.template.XATransactionalCodecTemplate
-
- CollectXATransactionsRequest - Class in com.hazelcast.transaction.client
-
- CollectXATransactionsRequest() - Constructor for class com.hazelcast.transaction.client.CollectXATransactionsRequest
-
- com.hazelcast - package com.hazelcast
-
- com.hazelcast.annotation - package com.hazelcast.annotation
-
Code generator annotations to mark processing options
- 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.eviction - package com.hazelcast.cache.impl.eviction
-
Eviction policy implementations for cache.
- com.hazelcast.cache.impl.eviction.impl - package com.hazelcast.cache.impl.eviction.impl
-
Eviction implementations for cache.
- com.hazelcast.cache.impl.eviction.impl.evaluator - package com.hazelcast.cache.impl.eviction.impl.evaluator
-
- com.hazelcast.cache.impl.eviction.impl.strategy - package com.hazelcast.cache.impl.eviction.impl.strategy
-
- com.hazelcast.cache.impl.eviction.impl.strategy.sampling - package com.hazelcast.cache.impl.eviction.impl.strategy.sampling
-
- 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.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.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.codec - package com.hazelcast.client.impl.protocol.codec
-
Client protocol custom codec implementations
- com.hazelcast.client.impl.protocol.parameters - package com.hazelcast.client.impl.protocol.parameters
-
- 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.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.template - package com.hazelcast.client.impl.protocol.template
-
- com.hazelcast.client.impl.protocol.util - package com.hazelcast.client.impl.protocol.util
-
Protocol utils
- com.hazelcast.client.nearcache - package com.hazelcast.client.nearcache
-
Contains classes/interfaces related to com.hazelcast.client.nearcache
- com.hazelcast.client.protocol.generator - package com.hazelcast.client.protocol.generator
-
Code generation for client protocol
- 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.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.collection - package com.hazelcast.collection
-
This package is currently a dummy package for collections.
- 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.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.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.monitors - package com.hazelcast.internal.monitors
-
Contains functionality what is happening in a HazelcastInstance.
- com.hazelcast.internal.osgi - package com.hazelcast.internal.osgi
-
This package contains the OSGI functionality for Hazelcast.
- com.hazelcast.internal.storage - package com.hazelcast.internal.storage
-
This package contains storage functionality for Hazelcast.
- com.hazelcast.jca - package com.hazelcast.jca
-
This package contains jca functionality
- com.hazelcast.jmx - package com.hazelcast.jmx
-
Contains Hazelcast management bean classes.
- 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.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.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.record - package com.hazelcast.map.impl.record
-
Contains record specific classes.
- 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.serialization.serializers - package com.hazelcast.nio.serialization.serializers
-
Contains interfaces/classes related to SerializerHook for ArrayList and LinkedList
- 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.iobalancer - package com.hazelcast.nio.tcp.iobalancer
-
Contains Handler Migration classes
- 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.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.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.impl - package com.hazelcast.replicatedmap.impl
-
This package contains the implementation of the replicated map service itself and some connection interfaces only used
internally - No public API!
- 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.messages - package com.hazelcast.replicatedmap.impl.messages
-
This package contains replication event classes to communicate replications to other nodes
- com.hazelcast.replicatedmap.impl.operation - package com.hazelcast.replicatedmap.impl.operation
-
This package contains some remote operations to execute 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.ringbuffer - package com.hazelcast.ringbuffer
-
- com.hazelcast.ringbuffer.impl - package com.hazelcast.ringbuffer.impl
-
- 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 Hazelcast SPI.
- com.hazelcast.spi.annotation - package com.hazelcast.spi.annotation
-
Contains annotations for Hazelcast SPI.
- 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.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.transceiver - package com.hazelcast.spi.impl.transceiver
-
- com.hazelcast.spi.impl.transceiver.impl - package com.hazelcast.spi.impl.transceiver.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.xa - package com.hazelcast.transaction.impl.xa
-
Provides implementation for Hazelcast XA transaction support.
- 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.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.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.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<Key, Value, ValueOut>) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.MappingJobImpl
-
- combiner(CombinerFactory<KeyIn, ValueIn, 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
Combiner
s.
- 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
-
- commit(String, long, boolean) - Method in interface com.hazelcast.client.impl.protocol.template.TransactionalCodecTemplate
-
- commit(String, boolean) - Method in interface com.hazelcast.client.impl.protocol.template.XATransactionalCodecTemplate
-
- 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(NodeEngine) - Method in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLog
-
- commit(NodeEngine) - Method in class com.hazelcast.collection.impl.txnqueue.QueueTransactionLog
-
- commit() - Method in class com.hazelcast.jca.HazelcastTransactionImpl
-
- commit(NodeEngine) - Method in class com.hazelcast.map.impl.tx.MapTransactionLog
-
- commit(NodeEngine) - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLog
-
- 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 interface com.hazelcast.transaction.impl.TransactionLog
-
- commit(Xid, boolean) - Method in class com.hazelcast.transaction.impl.xa.XAResourceImpl
-
- 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.collection.impl.txncollection.CollectionTransactionLog
-
- commitAsync(NodeEngine, ExecutionCallback) - Method in class com.hazelcast.collection.impl.txnqueue.QueueTransactionLog
-
- commitAsync(NodeEngine, ExecutionCallback) - Method in class com.hazelcast.map.impl.tx.MapTransactionLog
-
- commitAsync(NodeEngine, ExecutionCallback) - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLog
-
- commitAsync(NodeEngine, ExecutionCallback) - Method in interface com.hazelcast.transaction.impl.TransactionLog
-
- 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.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.client.impl.protocol.util.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.nio.DynamicByteBuffer
-
- compact() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
-
- 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(String, Object, Object) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- 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
-
- 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
- compareAndRemoveAll(String, Set<Data>) - Method in interface com.hazelcast.client.impl.protocol.template.ListCodecTemplate
-
- compareAndRemoveAll(String, Collection<Data>) - Method in interface com.hazelcast.client.impl.protocol.template.QueueCodecTemplate
-
- compareAndRemoveAll(String, Set<Data>) - Method in interface com.hazelcast.client.impl.protocol.template.SetCodecTemplate
-
- 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
-
- compareAndRetainAll(String, Set<Data>) - Method in interface com.hazelcast.client.impl.protocol.template.ListCodecTemplate
-
- compareAndRetainAll(String, Collection<Data>) - Method in interface com.hazelcast.client.impl.protocol.template.QueueCodecTemplate
-
- compareAndRetainAll(String, Set<Data>) - Method in interface com.hazelcast.client.impl.protocol.template.SetCodecTemplate
-
- compareAndSet(String, long, long) - Method in interface com.hazelcast.client.impl.protocol.template.AtomicLongCodecTemplate
-
- compareAndSet(String, Data, Data) - Method in interface com.hazelcast.client.impl.protocol.template.AtomicReferenceCodecTemplate
-
- 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(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
-
- completionId - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-
- completionId - Variable in class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
-
- compress(byte[]) - Static method in class com.hazelcast.nio.IOUtil
-
- 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.
- 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
-
- 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
-
- CONDITION_TEMPLATE_ID - Static variable in class com.hazelcast.client.impl.protocol.template.TemplateConstants
-
- 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
-
- ConditionCodecTemplate - Interface in com.hazelcast.client.impl.protocol.template
-
- 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.multimap.impl.MultiMapProxySupport
-
- config - Variable in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-
- config - Variable in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- 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.
- 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.
- 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
-
- 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
-
- CONNECT_ALL_WAIT_SECONDS - Variable in class com.hazelcast.instance.GroupProperties
-
- 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.AbstractSelectionHandler
-
- connection - Variable in class com.hazelcast.nio.tcp.DefaultPacketReader
-
- CONNECTION_MONITOR_INTERVAL - Variable in class com.hazelcast.instance.GroupProperties
-
- CONNECTION_MONITOR_MAX_FAULTS - Variable in class com.hazelcast.instance.GroupProperties
-
- connectionAdded(Connection) - Method in class com.hazelcast.client.spi.impl.ClusterListenerSupport
-
- connectionAdded(Connection) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- connectionAdded(Connection) - Method in interface com.hazelcast.nio.ConnectionListener
-
- connectionAdded(Connection) - Method in class com.hazelcast.nio.tcp.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
-
- 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.AbstractSelectionHandler
-
- 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.cluster.impl.ClusterServiceImpl
-
- connectionRemoved(Connection) - Method in interface com.hazelcast.nio.ConnectionListener
-
- connectionRemoved(Connection) - Method in class com.hazelcast.nio.tcp.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.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_BOOLEAN - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_BYTE - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_BYTE_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_CHAR - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_CHAR_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_DATA_SERIALIZABLE - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_DOUBLE - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_DOUBLE_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_FLOAT - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_FLOAT_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_INTEGER - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_INTEGER_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_LONG - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_LONG_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_NULL - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_PORTABLE - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_SHORT - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_SHORT_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_STRING - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- Constants - Class in com.hazelcast.aws.impl
-
- Constants() - Constructor for class com.hazelcast.aws.impl.Constants
-
- ConstantSerializers - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.BooleanSerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.BooleanSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.BooleanSerializer
-
- ConstantSerializers.ByteSerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.ByteSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.ByteSerializer
-
- ConstantSerializers.CharArraySerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.CharArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.CharArraySerializer
-
- ConstantSerializers.CharSerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.CharSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.CharSerializer
-
- ConstantSerializers.DoubleArraySerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.DoubleArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.DoubleArraySerializer
-
- ConstantSerializers.DoubleSerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.DoubleSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.DoubleSerializer
-
- ConstantSerializers.FloatArraySerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.FloatArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.FloatArraySerializer
-
- ConstantSerializers.FloatSerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.FloatSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.FloatSerializer
-
- ConstantSerializers.IntegerArraySerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.IntegerArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.IntegerArraySerializer
-
- ConstantSerializers.IntegerSerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.IntegerSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.IntegerSerializer
-
- ConstantSerializers.LongArraySerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.LongArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.LongArraySerializer
-
- ConstantSerializers.LongSerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.LongSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.LongSerializer
-
- ConstantSerializers.ShortArraySerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.ShortArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.ShortArraySerializer
-
- ConstantSerializers.ShortSerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.ShortSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.ShortSerializer
-
- ConstantSerializers.StringSerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.StringSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.StringSerializer
-
- ConstantSerializers.TheByteArraySerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.TheByteArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.TheByteArraySerializer
-
- ConstructorFunction<K,V> - Interface in com.hazelcast.util
-
See ConcurrencyUtil
- 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(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.AtomicReferenceCodecTemplate
-
- contains(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.ListCodecTemplate
-
- contains(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.QueueCodecTemplate
-
- contains(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.SetCodecTemplate
-
- contains(Object) - Method in class com.hazelcast.client.impl.protocol.util.Int2ObjectHashMap.KeySet
-
- contains(int) - Method in class com.hazelcast.client.impl.protocol.util.Int2ObjectHashMap.KeySet
-
- 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.ClientQueueProxy
-
- 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.MultiResultSet
-
- contains(Object) - Method in class com.hazelcast.query.impl.OrResultSet
-
- contains(Object) - Method in class com.hazelcast.query.impl.SingleResultSet
-
- contains(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
-
Legacy method testing if some key maps into the specified value
in this table.
- contains(QueryResultEntry) - Method in class com.hazelcast.util.QueryResultSet
-
- 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(String, Set<Data>) - Method in interface com.hazelcast.client.impl.protocol.template.ListCodecTemplate
-
- containsAll(String, Collection<Data>) - Method in interface com.hazelcast.client.impl.protocol.template.QueueCodecTemplate
-
- containsAll(String, Set<Data>) - Method in interface com.hazelcast.client.impl.protocol.template.SetCodecTemplate
-
- containsAll(Collection<?>) - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
-
- containsAll(Collection<?>) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-
- containsAll(Collection<?>) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-
- containsAll(Collection<?>) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
-
- containsAtomicLong(String) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-
- containsCollection(String) - Method in class com.hazelcast.multimap.impl.MultiMapPartitionContainer
-
- containsEntry(String, Data, Data, long) - Method in interface com.hazelcast.client.impl.protocol.template.MultiMapCodecTemplate
-
- 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(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.CacheCodecTemplate
-
- containsKey(String, Data, long) - Method in interface com.hazelcast.client.impl.protocol.template.MapCodecTemplate
-
- containsKey(String, Data, long) - Method in interface com.hazelcast.client.impl.protocol.template.MultiMapCodecTemplate
-
- containsKey(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.ReplicatedMapCodecTemplate
-
- containsKey(String, String, long, Data) - Method in interface com.hazelcast.client.impl.protocol.template.TransactionalMapCodecTemplate
-
- containsKey(Object) - Method in class com.hazelcast.client.impl.protocol.util.Int2ObjectHashMap
- containsKey(int) - Method in class com.hazelcast.client.impl.protocol.util.Int2ObjectHashMap
-
- 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 true
if this map contains an entry for the specified
key.
- containsKey(Object) - Method in interface com.hazelcast.core.IMap
-
Returns true
if 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(Data) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- containsKey(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- containsKey(Data) - Method in interface com.hazelcast.map.impl.RecordStore
-
- 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 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.ConcurrentReferenceHashMap
-
Tests if the specified object is a key in this table.
- 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
-
- 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.MultiMapWrapper
-
- containsReferenceContainer(String) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-
- 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(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.MapCodecTemplate
-
- containsValue(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.MultiMapCodecTemplate
-
- containsValue(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.ReplicatedMapCodecTemplate
-
- containsValue(Object) - Method in class com.hazelcast.client.impl.protocol.util.Int2ObjectHashMap
- 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.DefaultRecordStore
-
- containsValue(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- containsValue(Object) - Method in interface com.hazelcast.map.impl.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.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
-
- 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_PLAIN_TEXT - Static variable in class com.hazelcast.internal.ascii.rest.HttpCommand
-
- 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.
- 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(long, MemoryUnit) - Method in enum com.hazelcast.memory.MemoryUnit
-
- convert(Comparable) - Method in class com.hazelcast.query.impl.IdentityConverter
-
- convert(Comparable) - Method in class com.hazelcast.query.impl.UUIDConverter
-
- convert(Map.Entry, Comparable, Comparable) - Method in class com.hazelcast.query.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.VersionCheck
-
- convertToObjectKeys(Collection) - Method in class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
-
- convertToStringKey(Object, SerializationService) - Static method in class com.hazelcast.concurrent.lock.LockProxy
-
- convertTypeToCSharp(String) - Method in class com.hazelcast.client.protocol.generator.CodecModel.ParameterModel
-
- convertVersionToString(int) - Static method in class com.hazelcast.internal.management.ManagementCenterIdentifier
-
- copyCollections() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- copyToDirectBuffer(ByteBuffer, ByteBuffer) - Static method in class com.hazelcast.nio.IOUtil
-
- copyToHeapBuffer(ByteBuffer, ByteBuffer) - Static method in class com.hazelcast.nio.IOUtil
-
- CoreService - Interface in com.hazelcast.spi
-
Marker interface for core Hazelcast services.
- count(String, Data, long) - Method in interface com.hazelcast.client.impl.protocol.template.MultiMapCodecTemplate
-
- 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(String) - Method in interface com.hazelcast.client.impl.protocol.template.CountdownLatchCodecTemplate
-
- 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
-
- COUNTDOWN_LATCH_TEMPLATE_ID - Static variable in class com.hazelcast.client.impl.protocol.template.TemplateConstants
-
- 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
-
- CountdownLatchCodecTemplate - Interface in com.hazelcast.client.impl.protocol.template
-
- 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(long, int, int, long) - Method in interface com.hazelcast.client.impl.protocol.template.TransactionalCodecTemplate
-
- create(Xid, long) - Method in interface com.hazelcast.client.impl.protocol.template.XATransactionalCodecTemplate
-
- create(String) - Method in interface com.hazelcast.client.spi.ClientProxyFactory
-
- create(String, QueueStoreConfig, SerializationService) - Static method in class com.hazelcast.collection.impl.queue.QueueStoreWrapper
-
- create(ClassLoader) - Static method in class com.hazelcast.instance.NodeExtensionFactory
-
- create(MapServiceContext) - Static method in class com.hazelcast.map.impl.eviction.EvictionOperator
-
- create(MemoryInfoAccessor, MapServiceContext) - Static method in class com.hazelcast.map.impl.eviction.EvictionOperator
-
- create(int) - Method in class com.hazelcast.nio.serialization.ArrayDataSerializableFactory
-
- create(int) - Method in class com.hazelcast.nio.serialization.ArrayPortableFactory
-
- 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_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_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.
- 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
-
- createBackupEntryProcessor() - Method in interface com.hazelcast.cache.BackupAwareEntryProcessor
-
Either creates a new, specialized EntryProcessor
to be executed on the backup-partition, or returns
- 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
-
- createBindings() - Method in class com.hazelcast.internal.osgi.OSGiScriptEngine
-
- 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(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
-
- createCacheConfigIfAbsent(CacheConfig) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- createCacheConfigIfAbsent(CacheConfig) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- 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
-
- 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, String, int) - 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
- createClearOperationFactory() - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createClearOperationFactory() - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createClientLoginContext(Credentials) - Method in interface com.hazelcast.security.SecurityContext
-
- createClientUuid(Address) - Static method in class com.hazelcast.util.UuidUtil
-
- createClusterUuid() - Static method in class com.hazelcast.util.UuidUtil
-
- 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
-
- createConfig(Data, boolean) - Method in interface com.hazelcast.client.impl.protocol.template.CacheCodecTemplate
-
- 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(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
-
- createDefault(K, V, long, int) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntries
-
- createDefaultWriteBehindQueue() - Static method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueues
-
- 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.ResponseHandlerFactory
-
- 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
-
- createErrorLoggingResponseHandler(ILogger) - Static method in class com.hazelcast.spi.impl.ResponseHandlerFactory
-
- 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
-
- createExpirationTask() - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCache
-
- 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.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 interface com.hazelcast.nio.serialization.DataSerializerHook
-
- createFactory() - Method in interface com.hazelcast.nio.serialization.PortableHook
-
- createFactory() - Method in class com.hazelcast.partition.PartitionDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.partition.PartitionPortableHook
-
- 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.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.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
-
- 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
-
- createGetOperation(Data, ExpiryPolicy) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createGetOperation(Data, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- 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 instance
creation is split off to a separate method to allow subclasses to return a
customized / extended version of HazelcastHttpSession
.
- createInput(Data, SerializationService) - Method in interface com.hazelcast.nio.serialization.InputOutputFactory
-
- createInput(byte[], SerializationService) - Method in interface com.hazelcast.nio.serialization.InputOutputFactory
-
- createInputOutputFactory() - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- createInstance(Properties) - Static method in class com.hazelcast.hibernate.instance.HazelcastInstanceFactory
-
- 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() - Method in class com.hazelcast.instance.Node
-
- 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(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
-
- createLoadAllOperationFactory(Set<Data>, boolean) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createLoadAllOperationFactory(Set<Data>, boolean) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- 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
-
- createLockedValue(SoftLock) - Method in class com.hazelcast.hibernate.local.Value
-
- 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
-
- createMapService() - Method in interface com.hazelcast.map.impl.MapServiceFactory
-
- createMapSizeEstimator() - Static method in class com.hazelcast.map.impl.SizeEstimators
-
- createMapStoreContext(MapContainer) - Static method in class com.hazelcast.map.impl.mapstore.MapStoreContextFactory
-
- createMember(Address, String, String, Map<String, Object>) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- 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
-
- 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
-
- createMessageListener() - Method in class com.hazelcast.hibernate.local.TimestampsRegionCache
-
- createMessageTaskFactory(Node) - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- createMessageTaskFactory(Node) - Method in interface com.hazelcast.instance.NodeExtension
-
Creates factory method that creates server side client message handlers
- createNearCache(String, NearCacheConfig, NearCacheContext) - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCacheManager
-
- 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() - Static method in class com.hazelcast.map.impl.SizeEstimators
-
- 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
-
- 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 interface com.hazelcast.nio.serialization.SerializationService
-
- createObjectDataInput(Data) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- createObjectDataInput(byte[]) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- createObjectDataInput(Data) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- createObjectDataInputStream(InputStream) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- createObjectDataInputStream(InputStream) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- createObjectDataOutput(int) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- createObjectDataOutput(int) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- createObjectDataOutputStream(OutputStream) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- createObjectDataOutputStream(OutputStream) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- 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.EntrySetOperationFactory
-
- 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.MapFlushOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.MapGetAllOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.MapKeySetOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.MapLoadAllOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.MapPutAllOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.MapValuesOperationFactory
-
- 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.spi.impl.BinaryOperationFactory
-
- createOperation() - Method in interface com.hazelcast.spi.OperationFactory
-
Creates the operation.
- createOperation() - Method in class com.hazelcast.transaction.impl.xa.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.MapEntrySetMessageTask
-
- 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.MapGetAllMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapIsEmptyMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadGivenKeysMessageTask
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.protocol.task.map.MapPutAllMessageTask
-
- 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.map.MapValuesMessageTask
-
- 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.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.MapEntrySetRequest
-
- 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.MapGetAllRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapIsEmptyRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapKeySetRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapPutAllRequest
-
- 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.map.impl.client.MapValuesRequest
-
- 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.transaction.client.CollectXATransactionsRequest
-
- createOutput(int, SerializationService) - Method in interface com.hazelcast.nio.serialization.InputOutputFactory
-
- createPacketReader(TcpIpConnection, IOService) - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- createPacketReader(TcpIpConnection, IOService) - Method in interface com.hazelcast.instance.NodeExtension
-
Creates a PacketReader for given Connection instance.
- createPacketReader(TcpIpConnection) - Method in interface com.hazelcast.nio.IOService
-
- createPacketReader(TcpIpConnection) - Method in class com.hazelcast.nio.NodeIOService
-
- createPacketReader(TcpIpConnection) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- createPacketWriter(TcpIpConnection, IOService) - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- createPacketWriter(TcpIpConnection, IOService) - Method in interface com.hazelcast.instance.NodeExtension
-
Creates a PacketWriter for given Connection instance.
- createPacketWriter(TcpIpConnection) - Method in interface com.hazelcast.nio.IOService
-
- createPacketWriter(TcpIpConnection) - Method in class com.hazelcast.nio.NodeIOService
-
- createPacketWriter(TcpIpConnection) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- createPartitionRunner(int) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationRunnerFactory
-
Creates an OperationRunner for a given partition.
- createPortableReader(Data) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- createPortableReader(Data) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- createProxy(String, String) - Method in interface com.hazelcast.client.impl.protocol.template.ClientMessageTemplate
-
- 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
-
- 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
-
- 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
-
- 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, int, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createRecord(Object, long, long) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- createRecord(Data, Object, long, long) - Method in class com.hazelcast.map.impl.MapContainer
-
- createRecordCacheMap() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createRecordCacheMap() - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- createRecordWithExpiry(Data, Object, long, long, boolean, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createRecordWithExpiry(Data, Object, long, long, boolean, int, String) - 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
-
- createRemoteResponseHandler(NodeEngine, Operation) - Static method in class com.hazelcast.spi.impl.ResponseHandlerFactory
-
- createRemoveAllOperationFactory(Set<Data>, Integer) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createRemoveAllOperationFactory(Set<Data>, Integer) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createRemoveOperation(Data, Data, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createRemoveOperation(Data, Data, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- 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
-
- 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() - Method in interface com.hazelcast.client.ClientExtension
-
- createSerializationService() - 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.nio.serialization.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 class com.hazelcast.mapreduce.impl.JobPartitionStateArraySerializerHook
-
- createSerializer() - Method in class com.hazelcast.mapreduce.impl.JobPartitionStateSerializerHook
-
- createSerializer() - Method in interface com.hazelcast.nio.serialization.SerializerHook
-
Creates a new serializer for the serialization type
- createSerializer() - Method in class com.hazelcast.nio.serialization.serializers.ArrayListSerializerHook
-
- createSerializer() - Method in class com.hazelcast.nio.serialization.serializers.LinkedListSerializerHook
-
- 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.
- createSimpleEntryView(K, V, Record) - Static method in class com.hazelcast.map.impl.EntryViews
-
- createSimpleEntryView() - Static method in class com.hazelcast.map.impl.EntryViews
-
- 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
-
- 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
-
- createStats(String) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- createStoreEvent(E) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.StoreEvent
-
- createSymmetricReaderCipher(SymmetricEncryptionConfig) - Static method in class com.hazelcast.nio.CipherHelper
-
- createSymmetricWriterCipher(SymmetricEncryptionConfig) - Static method in class com.hazelcast.nio.CipherHelper
-
- 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, TransactionSupport) - Method in class com.hazelcast.collection.impl.list.ListService
-
- createTransactionalObject(String, TransactionSupport) - Method in class com.hazelcast.collection.impl.queue.QueueService
-
- createTransactionalObject(String, TransactionSupport) - Method in class com.hazelcast.collection.impl.set.SetService
-
- createTransactionalObject(String, TransactionSupport) - Method in class com.hazelcast.map.impl.MapService
-
- createTransactionalObject(String, TransactionSupport) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- createTransactionalObject(String, TransactionSupport) - 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
-
- createUnlockedValue() - Method in class com.hazelcast.hibernate.local.Value
-
- 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.
- 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.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.RecordInfo
-
- 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
-
- data - Variable in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
-
- DATA - Static variable in class com.hazelcast.client.impl.protocol.ResponseMessageConst
-
- Data(Data) - Method in interface com.hazelcast.client.impl.protocol.template.ResponseTemplate
-
- 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
-
- 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.EntryEventData
-
- dataKey - Variable in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- dataKey - Variable in class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-
- dataMergingValue - Variable in class com.hazelcast.map.impl.EntryEventData
-
- dataNewValue - Variable in class com.hazelcast.map.impl.EntryEventData
-
- dataOldValue - Variable in class com.hazelcast.map.impl.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
-
- DataRef - Interface in com.hazelcast.internal.storage
-
- DataReplicatedRecordStore - Class in com.hazelcast.replicatedmap.impl.record
-
- DataReplicatedRecordStore(String, NodeEngine, ReplicatedMapService) - 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.nio.serialization.DefaultSerializationServiceBuilder
-
- DataSerializableFactory - Interface in com.hazelcast.nio.serialization
-
DataSerializableFactory is used to create IdentifiedDataSerializable instances during de-serialization.
- DataSerializerHook - Interface in com.hazelcast.nio.serialization
-
- dataSize() - Method in interface com.hazelcast.nio.serialization.Data
-
Returns size of internal binary data in bytes
- dataSize() - Method in class com.hazelcast.nio.serialization.DefaultData
-
- 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_FORMAT - Static variable in class com.hazelcast.aws.impl.Constants
-
- 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
-
- DebugUtil - Class in com.hazelcast.util
-
Contains some debugging functionality; useful if you are running large testsuites and can't rely on a debugger.
- decode(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.AddressCodec
-
- decode(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.CacheEventDataCodec
-
- decode(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.DistributedObjectInfoCodec
-
- decode(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.EntryViewCodec
-
- decode(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.JobPartitionStateCodec
-
- decode(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MemberAttributeChangeCodec
-
- decode(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.MemberCodec
-
- decode(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.codec.XIDCodec
-
- decode(ClientMessage) - Static method in class com.hazelcast.client.impl.protocol.parameters.ExceptionResultParameters
-
- decode(byte[]) - Static method in class com.hazelcast.util.Base64
-
Decodes Base64 data into octects
- 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.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.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.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.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.GetDistributedObjectMessageTask
-
- 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.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.MapGetAsyncMessageTask
-
- 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.MapPutAsyncMessageTask
-
- 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.MapRemoveAsyncMessageTask
-
- 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.MultiMapCountMessageTask
-
- 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.RegisterMembershipListenerMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
-
- decodeClientMessage(ClientMessage) - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistrubtedObjectListenerMessageTask
-
- 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.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.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
-
- decompress(byte[]) - Static method in class com.hazelcast.nio.IOUtil
-
- decrementAndGet(String) - Method in interface com.hazelcast.client.impl.protocol.template.AtomicLongCodecTemplate
-
- 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
-
- decrementPacketCount() - 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_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_CHUNK_SIZE - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapPostJoinOperation
-
Default size for replication chunks
- 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_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.cache.impl.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_PASSWORD - Static variable in class com.hazelcast.config.GroupConfig
-
Default group password
- 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 QueryCache
as 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_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_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.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.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_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_TYPE_BIG_DECIMAL - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- DEFAULT_TYPE_BIG_INTEGER - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- DEFAULT_TYPE_CLASS - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- DEFAULT_TYPE_DATE - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- DEFAULT_TYPE_ENUM - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- DEFAULT_TYPE_EXTERNALIZABLE - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- DEFAULT_TYPE_OBJECT - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- 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
-
- defaultClassLoader - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- 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
-
- DefaultData - Class in com.hazelcast.nio.serialization
-
- DefaultData() - Constructor for class com.hazelcast.nio.serialization.DefaultData
-
- DefaultData(byte[]) - Constructor for class com.hazelcast.nio.serialization.DefaultData
-
- 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
-
- 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() - 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
-
- DefaultPacketReader - Class in com.hazelcast.nio.tcp
-
- DefaultPacketReader(TcpIpConnection, IOService) - Constructor for class com.hazelcast.nio.tcp.DefaultPacketReader
-
- DefaultPacketWriter - Class in com.hazelcast.nio.tcp
-
- DefaultPacketWriter() - Constructor for class com.hazelcast.nio.tcp.DefaultPacketWriter
-
- DefaultPartitioningStrategy - Class in com.hazelcast.partition.strategy
-
- DefaultPartitioningStrategy() - Constructor for class com.hazelcast.partition.strategy.DefaultPartitioningStrategy
-
- DefaultPortableReader - Class in com.hazelcast.nio.serialization
-
- DefaultPortableReader(PortableSerializer, BufferObjectDataInput, ClassDefinition) - Constructor for class com.hazelcast.nio.serialization.DefaultPortableReader
-
- DefaultPortableWriter - Class in com.hazelcast.nio.serialization
-
- DefaultPortableWriter(PortableSerializer, BufferObjectDataOutput, ClassDefinition) - Constructor for class com.hazelcast.nio.serialization.DefaultPortableWriter
-
- DefaultRecordStore - Class in com.hazelcast.map.impl
-
Default implementation of record-store.
- DefaultRecordStore(MapContainer, int, MapKeyLoader, ILogger) - Constructor for class com.hazelcast.map.impl.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.nio.serialization
-
- DefaultSerializationServiceBuilder() - Constructor for class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- DefaultSerializers - Class in com.hazelcast.nio.serialization
-
- DefaultSerializers.BigDecimalSerializer - Class in com.hazelcast.nio.serialization
-
- DefaultSerializers.BigDecimalSerializer() - Constructor for class com.hazelcast.nio.serialization.DefaultSerializers.BigDecimalSerializer
-
- DefaultSerializers.BigIntegerSerializer - Class in com.hazelcast.nio.serialization
-
- DefaultSerializers.BigIntegerSerializer() - Constructor for class com.hazelcast.nio.serialization.DefaultSerializers.BigIntegerSerializer
-
- DefaultSerializers.ClassSerializer - Class in com.hazelcast.nio.serialization
-
- DefaultSerializers.ClassSerializer() - Constructor for class com.hazelcast.nio.serialization.DefaultSerializers.ClassSerializer
-
- DefaultSerializers.DateSerializer - Class in com.hazelcast.nio.serialization
-
- DefaultSerializers.DateSerializer() - Constructor for class com.hazelcast.nio.serialization.DefaultSerializers.DateSerializer
-
- DefaultSerializers.EnumSerializer - Class in com.hazelcast.nio.serialization
-
- DefaultSerializers.EnumSerializer() - Constructor for class com.hazelcast.nio.serialization.DefaultSerializers.EnumSerializer
-
- DefaultSerializers.Externalizer - Class in com.hazelcast.nio.serialization
-
- DefaultSerializers.Externalizer(boolean) - Constructor for class com.hazelcast.nio.serialization.DefaultSerializers.Externalizer
-
- DefaultSerializers.ObjectSerializer - Class in com.hazelcast.nio.serialization
-
- DefaultSerializers.ObjectSerializer(boolean, boolean) - Constructor for class com.hazelcast.nio.serialization.DefaultSerializers.ObjectSerializer
-
- 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
-
- 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(String, Data, long) - Method in interface com.hazelcast.client.impl.protocol.template.MapCodecTemplate
-
- delete(String, String, long, Data) - Method in interface com.hazelcast.client.impl.protocol.template.TransactionalMapCodecTemplate
-
- 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(Data) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- 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 interface com.hazelcast.map.impl.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
-
- 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) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-
- 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
-
- 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
-
- 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(String, 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 and scans object with probe annotations.
- 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(String, String) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- deRegisterListener(String) - Method in interface com.hazelcast.client.spi.ClientListenerService
-
- deRegisterListener(String) - Method in class com.hazelcast.client.spi.impl.ClientListenerServiceImpl
-
- 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
-
- 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) - 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 class com.hazelcast.cache.impl.CachePartitionSegment
-
- 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(String) - Method in interface com.hazelcast.client.impl.protocol.template.CacheCodecTemplate
-
- destroy() - Method in class com.hazelcast.client.nearcache.ClientHeapNearCache
-
- destroy() - Method in interface com.hazelcast.client.nearcache.ClientNearCache
-
- 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 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.DefaultNodeExtension
-
- destroy() - Method in class com.hazelcast.instance.HazelcastThreadGroup
-
Destroys all threads in this ThreadGroup.
- destroy() - Method in interface com.hazelcast.instance.NodeExtension
-
Destroys NodeExtension.
- destroy() - Method in interface com.hazelcast.internal.storage.Storage
-
- destroy() - Method in class com.hazelcast.jca.ManagedConnectionImpl
-
- destroy() - Method in class com.hazelcast.jmx.ManagementService
-
- destroy() - Method in class com.hazelcast.map.impl.MapStoreWrapper
-
- 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 class com.hazelcast.nio.serialization.ConstantSerializers.TheByteArraySerializer
-
- destroy() - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- destroy() - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- destroy() - Method in interface com.hazelcast.nio.serialization.Serializer
-
Called when instance is shutting down.
- destroy() - Method in class com.hazelcast.nio.serialization.serializers.ArrayListSerializerHook.ArrayListStreamSerializer
-
- destroy() - Method in class com.hazelcast.nio.serialization.serializers.LinkedListSerializerHook.LinkedListStreamSerializer
-
- 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.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, boolean, String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- destroyCache(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- destroyCache(String, boolean, String) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- destroyCacheOnAllMembers(String, String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- destroyConnection(Connection) - Method in interface com.hazelcast.client.connection.ClientConnectionManager
-
Destroys the connection
Clears related resources of given connection.
- destroyConnection(Connection) - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-
- destroyConnection(Connection) - Method in interface com.hazelcast.nio.ConnectionManager
-
- 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.IndexService
-
- destroyJobSupervisor(JobSupervisor) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- destroyLocalDistributedObject(String, String, boolean) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-
- destroyMap(String) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- 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.
- destroyProxy(String, String) - Method in interface com.hazelcast.client.impl.protocol.template.ClientMessageTemplate
-
- 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
-
- didPing() - Method in class com.hazelcast.instance.MemberImpl
-
- didRead() - Method in class com.hazelcast.instance.MemberImpl
-
- didWrite() - Method in class com.hazelcast.instance.MemberImpl
-
- dispatchEvent(Object, CacheEventListener) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- dispatchEvent(ClientEndpointImpl, 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(EventData, 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.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
-
- disposeData(Data) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- disposeData(Data) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- 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
-
- distributeClear(boolean) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicationPublisher
-
- DISTRIBUTED_OBJECT - Static variable in class com.hazelcast.client.impl.protocol.ResponseMessageConst
-
- 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(String, String, String) - Method in interface com.hazelcast.client.impl.protocol.template.EventResponseTemplate
-
- DistributedObject(Collection<DistributedObjectInfo>) - Method in interface com.hazelcast.client.impl.protocol.template.ResponseTemplate
-
- DistributedObject - Interface in com.hazelcast.core
-
Base interface for all distributed objects.
- 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.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, 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
-
- DistributedObjectEventPacket() - Constructor for class com.hazelcast.spi.impl.DistributedObjectEventPacket
-
- DistributedObjectEventPacket(DistributedObjectEvent.EventType, String, String) - Constructor for class com.hazelcast.spi.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
-
- DistributedObjectInfoCodec - Class in com.hazelcast.client.impl.protocol.codec
-
- DistributedObjectListener - Interface in com.hazelcast.core
-
DistributedObjectListener notifies when a
DistributedObject
is created or destroyed cluster-wide.
- DistributedObjectListenerRequest - Class in com.hazelcast.client.impl.client
-
- DistributedObjectListenerRequest() - Constructor for class com.hazelcast.client.impl.client.DistributedObjectListenerRequest
-
- 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.
- doActualRead(ByteBuffer) - Method in class com.hazelcast.internal.ascii.rest.HttpPostCommand
-
- DOC_VERSION - Static variable in class com.hazelcast.aws.impl.Constants
-
- doCheck(Node, String, boolean) - Method in class com.hazelcast.util.VersionCheck
-
- 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(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
-
- doneProcessing() - Method in class com.hazelcast.partition.MigrationInfo
-
- 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_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
-
- 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
-
- DoubleProbe<S> - Interface in com.hazelcast.internal.metrics
-
- 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(String) - Method in interface com.hazelcast.client.impl.protocol.template.SemaphoreCodecTemplate
-
- 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(String) - Method in interface com.hazelcast.client.impl.protocol.template.QueueCodecTemplate
-
- 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.
- drainToMaxSize(String, int) - Method in interface com.hazelcast.client.impl.protocol.template.QueueCodecTemplate
-
- dumpAllThreads() - Static method in class com.hazelcast.internal.management.ThreadDumpGenerator
-
- dumpDeadlocks() - Static method in class com.hazelcast.internal.management.ThreadDumpGenerator
-
- dumpPerformanceMetrics(StringBuffer) - Method in interface com.hazelcast.nio.ConnectionManager
-
Dumps all kinds of performance metrics.
- dumpPerformanceMetrics(StringBuffer) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- dumpPerformanceMetrics(StringBuffer) - Method in class com.hazelcast.spi.impl.operationexecutor.classic.ClassicOperationExecutor
-
- dumpPerformanceMetrics(StringBuffer) - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
-
Deprecated.
- dumpPerformanceMetrics(StringBuffer) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-
- dumpPerformanceMetrics(StringBuffer) - Method in interface com.hazelcast.spi.OperationService
-
Deprecated.
- duplicate() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- 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
-
- DynamicByteBuffer - Class in com.hazelcast.nio
-
- DynamicByteBuffer(int, boolean) - Constructor for class com.hazelcast.nio.DynamicByteBuffer
-
- DynamicByteBuffer(byte[]) - Constructor for class com.hazelcast.nio.DynamicByteBuffer
-
- DynamicByteBuffer(byte[], int, int) - Constructor for class com.hazelcast.nio.DynamicByteBuffer
-
- DynamicByteBuffer(ByteBuffer) - Constructor for class com.hazelcast.nio.DynamicByteBuffer
-
- 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.
- Gauge - Interface in com.hazelcast.internal.metrics
-
A gauge metric is an instantaneous reading of a particular value: for example, the current size of the pending
operations queue.
- GaugeImpl<S> - Class in com.hazelcast.internal.metrics.impl
-
Default
Metric
implementation.
- GaugeImpl(String, ILogger) - Constructor for class com.hazelcast.internal.metrics.impl.GaugeImpl
-
- 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.
- GenerateCodec - Annotation Type in com.hazelcast.annotation
-
This annotation is for marking template interfaces to be processed
- generateCodec(ExecutableElement, Lang) - Method in class com.hazelcast.client.protocol.generator.CodecCodeGenerator
-
- generateInterceptorId(String, MapInterceptor) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
-
- GenerateMessageTaskFactory - Annotation Type in com.hazelcast.annotation
-
This annotation is for marking packages to generate MessageTaskFactory registry
- GENERIC_ERROR - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-
- GENERIC_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
-
- GENERIC_OPERATION_THREAD_COUNT - Variable in class com.hazelcast.instance.GroupProperties
-
- 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 null
if 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(String) - Method in interface com.hazelcast.client.impl.protocol.template.AtomicLongCodecTemplate
-
- get(String) - Method in interface com.hazelcast.client.impl.protocol.template.AtomicReferenceCodecTemplate
-
- get(String, Data, Data) - Method in interface com.hazelcast.client.impl.protocol.template.CacheCodecTemplate
-
- get(String, int) - Method in interface com.hazelcast.client.impl.protocol.template.ListCodecTemplate
-
- get(String, Data, long) - Method in interface com.hazelcast.client.impl.protocol.template.MapCodecTemplate
-
- get(String, Data, long) - Method in interface com.hazelcast.client.impl.protocol.template.MultiMapCodecTemplate
-
- get(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.ReplicatedMapCodecTemplate
-
- get(String, String, long, Data) - Method in interface com.hazelcast.client.impl.protocol.template.TransactionalMapCodecTemplate
-
- get(String, String, long, Data) - Method in interface com.hazelcast.client.impl.protocol.template.TransactionalMultiMapCodecTemplate
-
- get(Object) - Method in class com.hazelcast.client.impl.protocol.util.Int2ObjectHashMap
- get(int) - Method in class com.hazelcast.client.impl.protocol.util.Int2ObjectHashMap
-
- get() - Method in interface com.hazelcast.client.impl.protocol.util.Int2ObjectHashMap.Supplier
-
Gets a result.
- get(K) - Method in class com.hazelcast.client.nearcache.ClientHeapNearCache
-
- get(K) - Method in interface com.hazelcast.client.nearcache.ClientNearCache
-
- 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 null
if 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 null
if 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) - Method in class com.hazelcast.hibernate.distributed.IMapRegionCache
-
- get(Object) - 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) - 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.DoubleProbe
-
Gets the current value of the source object.
- get(S) - Method in interface com.hazelcast.internal.metrics.LongProbe
-
Gets the current value of the source object as a long.
- get(String) - Method in class com.hazelcast.internal.osgi.OSGiScriptEngine
-
- get(String) - Method in class com.hazelcast.internal.osgi.OSGiScriptEngineManager
-
- get(int, REF) - Method in interface com.hazelcast.internal.storage.Storage
-
- get(Data, boolean) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- 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
-
- get(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- get(Data, boolean) - Method in interface com.hazelcast.map.impl.RecordStore
-
- get(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- get(Object) - Method in interface com.hazelcast.map.QueryCache
-
- get(long, TimeUnit) - Method in class com.hazelcast.mapreduce.impl.task.TrackableJobFuture
-
- 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() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- get(int) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- get(byte[]) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- get(byte[], int, int) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- get(byte) - Static method in enum com.hazelcast.nio.serialization.FieldType
-
- 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 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.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) - 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(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 class com.hazelcast.util.ConcurrentReferenceHashMap
-
Returns the value to which the specified key is mapped,
or null
if 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(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_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 class com.hazelcast.cache.impl.CacheEventContext
-
- getAccessHit() - Method in interface com.hazelcast.cache.impl.eviction.Evictable
-
- getAccessHit() - Method in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-
- getAccessHit() - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-
- getAccessKey() - Method in class com.hazelcast.config.AwsConfig
-
Gets the access key to access AWS.
- getAccessor() - Method in interface com.hazelcast.cache.impl.eviction.EvictionCandidate
-
The accessor (key or id) of
Evictable
entry or record or whatever.
- getAccessor() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.HeapNearCacheRecordMap.EvictableSamplingEntry
-
- getAccessor() - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap.EvictableSamplingEntry
-
- getAccessTime() - Method in interface com.hazelcast.cache.impl.eviction.Evictable
-
Gets the latest access time difference of this
Evictable
in milliseconds.
- getAccessTime() - Method in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-
- getAccessTime() - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-
- 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
-
- getActiveConnectionCount() - 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
-
- 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 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(String, Set<Data>, Data) - Method in interface com.hazelcast.client.impl.protocol.template.CacheCodecTemplate
-
- getAll(String) - Method in interface com.hazelcast.client.impl.protocol.template.ListCodecTemplate
-
- getAll(String, Set<Data>) - Method in interface com.hazelcast.client.impl.protocol.template.MapCodecTemplate
-
- getAll(String) - Method in interface com.hazelcast.client.impl.protocol.template.SetCodecTemplate
-
- 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<Data>) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- getAll(Set<K>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- getAll(Set<Data>) - Method in interface com.hazelcast.map.impl.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
-
- 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
-
- 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
-
- 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, Set<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
-
- 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
-
- 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(String, long) - Method in interface com.hazelcast.client.impl.protocol.template.AtomicLongCodecTemplate
-
- 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(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.AtomicLongCodecTemplate
-
- getAndAlter(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.AtomicReferenceCodecTemplate
-
- 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(String) - Method in interface com.hazelcast.client.impl.protocol.template.AtomicLongCodecTemplate
-
- 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
-
- getAndRemove(String, Data, int) - Method in interface com.hazelcast.client.impl.protocol.template.CacheCodecTemplate
-
- 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 ExpiryPolicy
and 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
-
- getAndReplace(String, Data, Data, Data, int) - Method in interface com.hazelcast.client.impl.protocol.template.CacheCodecTemplate
-
- 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 ExpiryPolicy
and returns the previously assigned value.
- getAndSet(String, long) - Method in interface com.hazelcast.client.impl.protocol.template.AtomicLongCodecTemplate
-
- getAndSet(String, Data) - Method in interface com.hazelcast.client.impl.protocol.template.AtomicReferenceCodecTemplate
-
- 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
-
- getApproximateMaxSize(MaxSizeConfig, MaxSizeConfig.MaxSizePolicy) - Static method in class com.hazelcast.map.impl.eviction.MaxSizeChecker
-
Get max size setting form config for given policy
- 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 config.
- getAsReadOnly() - Method in class com.hazelcast.config.CacheEvictionConfig
-
Deprecated.
- 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.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.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(String, Data, long) - Method in interface com.hazelcast.client.impl.protocol.template.MapCodecTemplate
-
- 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.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.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.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.ClearRemoteTransactionOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.transaction.impl.xa.FinalizeRemoteTransactionOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.transaction.impl.xa.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
-
- 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(String) - Method in interface com.hazelcast.query.impl.QueryableEntry
-
- getAttribute(String) - Method in class com.hazelcast.query.impl.QueryEntry
-
- 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 and
adds current jvmId into SessionState.
- 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 and
adds current jvmId into SessionState.
- 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(Class) - Static method in class com.hazelcast.query.impl.getters.ReflectionHelper
-
- getAttributeType(Object, String) - Static method in class com.hazelcast.query.impl.getters.ReflectionHelper
-
- getAttributeType(String) - Method in interface com.hazelcast.query.impl.QueryableEntry
-
- getAttributeType(String) - Method in class com.hazelcast.query.impl.QueryEntry
-
- getAvailable() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreContainer
-
- getAvailable() - Method in class com.hazelcast.jmx.SemaphoreMBean
-
- 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.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.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.ClearRemoteTransactionOperation
-
- getBackupOperation() - Method in class com.hazelcast.transaction.impl.xa.FinalizeRemoteTransactionOperation
-
- getBackupOperation() - Method in class com.hazelcast.transaction.impl.xa.PutRemoteTransactionOperation
-
- 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
-
- getBaseName(String) - Static method in class com.hazelcast.partition.strategy.StringPartitioningStrategy
-
- getBatchSize() - Method in class com.hazelcast.config.QueryCacheConfig
-
After reaching this size, node sends buffered events to QueryCache
.
- getBindAddress() - Method in interface com.hazelcast.instance.AddressPicker
-
Returns a server socket listener address.
- getBindings(int) - Method in class com.hazelcast.internal.osgi.OSGiScriptEngine
-
- getBindings() - Method in class com.hazelcast.internal.osgi.OSGiScriptEngineManager
-
- getBoolean() - Method in class com.hazelcast.client.config.ClientProperties.ClientProperty
-
- getBoolean() - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-
- getBoolean() - Method in class com.hazelcast.instance.GroupProperties.GroupProperty
-
- 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
-
- 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 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 interface com.hazelcast.nio.serialization.PortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.partition.PartitionPortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- 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.ringbuffer.OverflowPolicy
-
Returns the OverflowPolicy for the given id.
- getByte() - Method in class com.hazelcast.client.config.ClientProperties.ClientProperty
-
- getByte(int) - Method in interface com.hazelcast.client.impl.protocol.util.ClientProtocolBuffer
-
Get the value at a given index.
- getByte(int) - Method in class com.hazelcast.client.impl.protocol.util.SafeBuffer
-
- getByte(int) - Method in class com.hazelcast.client.impl.protocol.util.UnsafeBuffer
-
- getByte() - Method in class com.hazelcast.instance.GroupProperties.GroupProperty
-
- 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 interface com.hazelcast.nio.ObjectDataInput
-
- getByteOrder() - Method in interface com.hazelcast.nio.ObjectDataOutput
-
- getByteOrder() - Method in interface com.hazelcast.nio.serialization.InputOutputFactory
-
- getByteOrder() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- getByteOrder() - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
-
- getByteOrder() - Method in interface com.hazelcast.nio.serialization.PortableContext
-
- getByteOrder() - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- getByteOrder() - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- 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(String) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-
- 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.AbstractCacheService
-
- 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
-
- getCacheDataDescription() - Method in class com.hazelcast.hibernate.region.AbstractTransactionalDataRegion
-
- getCachedValue() - Method in interface com.hazelcast.map.impl.record.Record
-
- 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
-
- 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.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.
- 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
-
- 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 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
-
- getCacheRecordStore(String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- getCacheRecordStore(String, int) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- 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
.
- getCacheUnchecked(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- 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.EventData
-
- getCallerAddress() - Method in class com.hazelcast.spi.Operation
-
- getCallerUuid() - Method in class com.hazelcast.spi.Operation
-
- 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.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
-
- getChar() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- getChar(int) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- 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
-
- 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.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.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.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.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.DistributedObjectListenerRequest
-
- 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.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.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.MapEntrySetRequest
-
- 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.MapKeySetRequest
-
- 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.MapValuesRequest
-
- 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
-
- 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.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.ReplicatedMapEntrySet
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapGetResponse
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeySet
-
- 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.security.UsernamePasswordCredentials
-
- 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 interface com.hazelcast.nio.ObjectDataInput
-
Returns class loader that internally used for objects
- getClassLoader() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- getClassLoader() - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- getClassLoader() - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- getClassName() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
-
- getClassName() - Method in class com.hazelcast.client.protocol.generator.CodecModel
-
- getClassName() - Method in class com.hazelcast.client.protocol.generator.MessageFactoryModel
-
- getClassName() - Method in class com.hazelcast.client.protocol.generator.MessageTypeEnumModel
-
- getClassName() - Method in class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
-
- getClassName() - Method in class com.hazelcast.config.CredentialsFactoryConfig
-
- 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.nio.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
-
- 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
-
- 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.impl.ClientEndpointImpl
-
- getClientType() - Method in class com.hazelcast.client.impl.ClientImpl
-
- getClientType() - Method in interface com.hazelcast.core.Client
-
Returns the type of this client.
- 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
-
- getClusterId() - Method in interface com.hazelcast.cluster.ClusterService
-
Returns UUID for the cluster.
- getClusterId() - 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
-
- getClusterProxy() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- 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
-
- 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.ClusterProxy
-
- getClusterTime() - Method in interface com.hazelcast.core.Cluster
-
Returns the cluster-wide time in milliseconds.
- getClusterTime() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getClusterTimeDiff() - Method in interface com.hazelcast.cluster.ClusterClock
-
- getClusterTimeDiff() - Method in class com.hazelcast.cluster.impl.ClusterClockImpl
-
- 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
-
- 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.MultiMapWrapper
-
- 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.SerializableCollection
-
- getCollectionContainer(String) - Method in class com.hazelcast.multimap.impl.MultiMapPartitionContainer
-
- getCollectionWrapper() - Method in class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-
- 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.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 interface com.hazelcast.cache.impl.operation.MutableOperation
-
- getConcurrencyLevel() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- 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(String, String) - Method in interface com.hazelcast.client.impl.protocol.template.CacheCodecTemplate
-
- 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.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
-
- getConfigurationUrl() - Method in class com.hazelcast.config.Config
-
- getConfigurationUrl() - Method in class com.hazelcast.config.XmlConfigLocator
-
- 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
-
- 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
-
- 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
-
- getContext() - Method in class com.hazelcast.internal.osgi.OSGiScriptEngine
-
- getConverter() - Method in enum com.hazelcast.query.impl.AttributeType
-
- 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.NearCacheRecord
-
- getCost() - Method in interface com.hazelcast.map.impl.record.Record
-
- getCost() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getCost(T) - Method in interface com.hazelcast.map.impl.SizeEstimator
-
- getCount() - Method in class com.hazelcast.cache.impl.CacheKeyIteratorResult
-
- getCount(String) - Method in interface com.hazelcast.client.impl.protocol.template.CountdownLatchCodecTemplate
-
- 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.impl.eviction.Evictable
-
Gets the creation time of this
Evictable
in milliseconds.
- 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 class com.hazelcast.hibernate.local.Value
-
- 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.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.web.HazelcastHttpSession
-
- 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
-
- 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
-
- 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
-
- getData() - Method in class com.hazelcast.nio.Packet
-
- getDataEntrySet() - Method in class com.hazelcast.multimap.impl.operations.EntrySetResponse
-
- getDataFromMap(long) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
- getDataGetterString() - Method in class com.hazelcast.client.protocol.generator.CodecModel.ParameterModel
-
- getDataGetterStringCSharp() - Method in class com.hazelcast.client.protocol.generator.CodecModel.ParameterModel
-
- getDataGetterStringJava() - Method in class com.hazelcast.client.protocol.generator.CodecModel.ParameterModel
-
- 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.EntryEventData
-
- getDataList() - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-
- getDataMergingValue() - Method in class com.hazelcast.map.impl.EntryEventData
-
- getDataNewValue() - Method in class com.hazelcast.map.impl.EntryEventData
-
- 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.EntryEventData
-
- getDataSerializableFactories() - Method in class com.hazelcast.config.SerializationConfig
-
- getDataSerializableFactoryClasses() - Method in class com.hazelcast.config.SerializationConfig
-
- getDataSet() - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-
- getDataSetterString() - Method in class com.hazelcast.client.protocol.generator.CodecModel.ParameterModel
-
- getDataSetterStringJava() - Method in class com.hazelcast.client.protocol.generator.CodecModel.ParameterModel
-
- 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 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.cache.impl.eviction.EvictionStrategyProvider
-
- 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
-
- 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
- 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).
- getDistributedObject(String, Object) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
Deprecated.
- getDistributedObject(String, String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getDistributedObject(String, Object) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
Deprecated.
- getDistributedObject(String, String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- getDistributedObject() - Method in interface com.hazelcast.client.impl.protocol.template.ClientMessageTemplate
-
- getDistributedObject() - Method in class com.hazelcast.core.DistributedObjectEvent
-
Returns the DistributedObject instance.
- getDistributedObject(String, Object) - Method in interface com.hazelcast.core.HazelcastInstance
-
- getDistributedObject(String, String) - Method in interface com.hazelcast.core.HazelcastInstance
-
- getDistributedObject(String, Object) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
Deprecated.
- getDistributedObject(String, String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getDistributedObject(String, Object) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getDistributedObject(String, String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getDistributedObject(String, Object) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-
Deprecated.
- 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
-
- GetDistributedObjectMessageTask - Class in com.hazelcast.client.impl.protocol.task
-
- GetDistributedObjectMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.GetDistributedObjectMessageTask
-
- 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.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.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.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.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.GetDistributedObjectMessageTask
-
- 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.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.MapGetAsyncMessageTask
-
- 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.MapPutAsyncMessageTask
-
- 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.MapRemoveAsyncMessageTask
-
- 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.MultiMapCountMessageTask
-
- 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.RegisterMembershipListenerMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistrubtedObjectListenerMessageTask
-
- 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.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.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.GetLockCountRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-
- 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.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.MapEntrySetRequest
-
- 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.MapKeySetRequest
-
- 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.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.map.impl.client.MapValuesRequest
-
- 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.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
-
- 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() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- getDouble(int) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- 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
-
- 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.internal.osgi.OSGiScriptEngineManager
-
- getEngineByMimeType(String) - Method in class com.hazelcast.internal.osgi.OSGiScriptEngineManager
-
- getEngineByName(String) - Method in class com.hazelcast.internal.osgi.OSGiScriptEngineManager
-
- getEngineFactories() - Method in class com.hazelcast.internal.osgi.OSGiScriptEngineManager
-
- getEngineName() - Method in class com.hazelcast.internal.osgi.OSGiScriptEngineFactory
-
- getEngineVersion() - Method in class com.hazelcast.internal.osgi.OSGiScriptEngineFactory
-
- getEntries() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- 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.map.impl.MapEntrySet
-
- getEntrySet() - Method in class com.hazelcast.multimap.impl.client.PortableEntrySetResponse
-
- getEntrySet() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntrySet
-
- getEntryView(String, Data, long) - Method in interface com.hazelcast.client.impl.protocol.template.MapCodecTemplate
-
- 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
-
- getEvent() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventPacket
-
- getEventCount() - Method in interface com.hazelcast.nio.tcp.MigratableHandler
-
Get number of events recorded by the current handler.
- getEventCount() - Method in class com.hazelcast.nio.tcp.ReadHandler
-
- getEventCount() - Method in class com.hazelcast.nio.tcp.WriteHandler
-
- getEventExecutor() - Method in class com.hazelcast.client.spi.impl.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.client.MapAddNearCacheEntryListenerRequest
-
- getEventGetterString() - Method in class com.hazelcast.client.protocol.generator.CodecModel.ParameterModel
-
- getEventHandler(int) - Method in interface com.hazelcast.client.spi.ClientInvocationService
-
- getEventId() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventPacket
-
- 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
- getEventParams() - Method in class com.hazelcast.client.protocol.generator.CodecModel.EventModel
-
- getEventQueueCapacity() - Method in class com.hazelcast.client.config.ClientProperties
-
- 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
-
- getEvents() - Method in class com.hazelcast.client.protocol.generator.CodecModel
-
- 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.client.config.ClientProperties
-
- 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.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.EventData
-
- getEventType() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-
- getEventType() - Method in class com.hazelcast.spi.impl.DistributedObjectEventPacket
-
- 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
-
- getEvictable() - Method in interface com.hazelcast.cache.impl.eviction.EvictionCandidate
-
The value of
Evictable
entry or record or whatever.
- getEvictable() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.HeapNearCacheRecordMap.EvictableSamplingEntry
-
- getEvictable() - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap.EvictableSamplingEntry
-
- 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
-
- getEvictionConfig() - Method in class com.hazelcast.config.QueryCacheConfig
-
- getEvictionConfig(Node) - Method in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
-
- 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
-
- getEvictionOperator() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- 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
-
- getEvictionPolicyEvaluator(EvictionConfiguration) - Static method in class com.hazelcast.cache.impl.eviction.EvictionPolicyEvaluatorProvider
-
- getEvictionPolicyType() - Method in interface com.hazelcast.cache.impl.eviction.EvictionConfiguration
-
Gets the type of eviction policy.
- getEvictionPolicyType() - Method in class com.hazelcast.config.EvictionConfig
-
- getEvictionStrategy(EvictionConfiguration) - Static method in class com.hazelcast.cache.impl.eviction.EvictionStrategyProvider
-
- getEvictionStrategyType() - Method in interface com.hazelcast.cache.impl.eviction.EvictionConfiguration
-
Gets the type of eviction strategy.
- getEvictionStrategyType() - Method in class com.hazelcast.config.EvictionConfig
-
- 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.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 class com.hazelcast.cache.impl.CacheEventContext
-
- getExpirationTime() - Method in interface com.hazelcast.cache.impl.eviction.Expirable
-
Gets the expiration time in milliseconds.
- 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 class com.hazelcast.map.impl.record.RecordStatistics
-
- getExpirationTime() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- 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.internal.osgi.OSGiScriptEngineFactory
-
- getFactory() - Method in class com.hazelcast.internal.osgi.OSGiScriptEngine
-
- 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.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.CacheRemoveEntryListenerRequest
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheRemoveInvalidationListenerRequest
-
- 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.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.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.DistributedObjectListenerRequest
-
- 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.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.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.instance.MemberImpl
-
- 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.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.MapEntrySetRequest
-
- 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.MapKeySetRequest
-
- 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.client.MapValuesRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.MapDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.map.impl.MapEntrySet
-
- 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.SimpleEntryView
-
- 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
-
- getFactoryId() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.DataSerializerHook
-
- getFactoryId(String, int) - Static method in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- 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 interface com.hazelcast.nio.serialization.PortableHook
-
- 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.query.impl.QueryResultEntryImpl
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntrySet
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapGetResponse
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeySet
-
- 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.messages.MultiReplicationMessage
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.messages.ReplicationMessage
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapClearOperation
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapInitChunkOperation
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapPostJoinOperation
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.record.VectorClockTimestamp
-
- 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.EventPacket
-
- 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.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.SerializableCollection
-
- 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.util.QueryResultSet
-
- 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 interface com.hazelcast.nio.serialization.ClassDefinition
-
- getField(int) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
- getFieldClassId(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
- getFieldClassId(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- getFieldClassId(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- getFieldCount() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
- getFieldDefinition(ClassDefinition, String) - Method in interface com.hazelcast.nio.serialization.PortableContext
-
- getFieldNames() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
- getFieldNames() - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- getFieldNames() - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- getFieldType(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
- getFieldType(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- getFieldType(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- getFilter() - Method in class com.hazelcast.map.impl.SyntheticEventFilter
-
- getFilter() - Method in interface com.hazelcast.spi.EventRegistration
-
- getFilter() - Method in class com.hazelcast.spi.impl.eventservice.impl.Registration
-
- 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.Predicates.ILikePredicate
-
- getFlags() - Method in class com.hazelcast.query.Predicates.LikePredicate
-
- getFloat() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- getFloat(int) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- 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(String, String, long, Data) - Method in interface com.hazelcast.client.impl.protocol.template.TransactionalMapCodecTemplate
-
- 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 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.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
-
- getGauge(String) - Method in class com.hazelcast.internal.metrics.impl.MetricsRegistryImpl
-
- getGauge(String) - Method in interface com.hazelcast.internal.metrics.MetricsRegistry
-
Gets the Gauge for a given name.
- 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.ClientInvocation
-
- getHandler() - Method in class com.hazelcast.client.spi.impl.ClientInvocationFuture
-
- 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
-
Tries to extract HazelcastInstance
from Session
.
- getHazelcastInstance(SessionFactory) - Static method in class com.hazelcast.hibernate.instance.HazelcastAccessor
-
Tries to extract HazelcastInstance
from SessionFactory
.
- getHazelcastInstance(SessionFactoryImplementor) - Static method in class com.hazelcast.hibernate.instance.HazelcastAccessor
-
Tries to extract HazelcastInstance
from SessionFactoryImplementor
.
- 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.
- getHazelcastInstanceByName(String) - Static method in class com.hazelcast.core.Hazelcast
-
Returns an existing HazelcastInstance with instanceName.
- 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 interface com.hazelcast.map.impl.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.
- getHeapCost() - Method in class com.hazelcast.nio.serialization.DefaultData
-
- getHeartbeatInterval() - Method in class com.hazelcast.client.config.ClientProperties
-
- getHeartBeatInterval() - Method in class com.hazelcast.client.spi.impl.ClientInvocation
-
- getHeartbeatTimeout() - Method in class com.hazelcast.client.config.ClientProperties
-
- getHits() - Method in interface com.hazelcast.core.EntryView
-
Returns number of hits of the entry.
- getHits() - Method in class com.hazelcast.map.impl.record.RecordStatistics
-
- 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.MultiMapWrapper
-
- 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.
- 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.CachePutAllBackupOperation
-
- 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 class com.hazelcast.client.nearcache.ClientHeapNearCache
-
- getId() - Method in interface com.hazelcast.client.nearcache.ClientNearCache
-
- getId() - Method in class com.hazelcast.client.protocol.generator.MessageTypeEnumModel.ParameterModel
-
- 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.HeartbeatOperation
-
- 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 interface com.hazelcast.core.DistributedObject
-
- 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.instance.MemberImpl
-
- getId() - Method in class com.hazelcast.map.impl.MapEntrySet
-
- 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.SimpleEntryView
-
- 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.AbstractJobTracker
-
- 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 class com.hazelcast.partition.client.PartitionsResponse
-
- getId() - Method in class com.hazelcast.query.impl.QueryResultEntryImpl
-
- getId() - Method in class com.hazelcast.replicatedmap.impl.messages.MultiReplicationMessage
-
- getId() - Method in class com.hazelcast.replicatedmap.impl.messages.ReplicationMessage
-
- getId() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapClearOperation
-
- getId() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapInitChunkOperation
-
- getId() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapPostJoinOperation
-
- getId() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- getId() - Method in class com.hazelcast.replicatedmap.impl.record.VectorClockTimestamp
-
- 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 class com.hazelcast.spi.AbstractDistributedObject
-
Deprecated.
- 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.EventPacket
-
- 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.SerializableCollection
-
- 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.util.QueryResultSet
-
- 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
-
- 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
-
- getImpl() - Method in class com.hazelcast.map.impl.MapStoreWrapper
-
- 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
-
- 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 interface com.hazelcast.nio.serialization.FieldDefinition
-
- getIndex(String) - Method in class com.hazelcast.query.impl.QueryContext
-
- getIndex(QueryContext) - Method in class com.hazelcast.query.Predicates.AbstractPredicate
-
- getIndexConfigs() - Method in class com.hazelcast.config.QueryCacheConfig
-
- getIndexes() - Method in class com.hazelcast.query.impl.IndexService
-
- getIndexKey() - Method in class com.hazelcast.query.impl.QueryEntry
-
- getIndexKey() - Method in interface com.hazelcast.query.impl.QueryResultEntry
-
- getIndexKey() - Method in class com.hazelcast.query.impl.QueryResultEntryImpl
-
- getIndexService() - Method in class com.hazelcast.map.impl.MapContainer
-
- 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.nearcache.ClientHeapNearCache
-
- getInMemoryFormat() - Method in interface com.hazelcast.client.nearcache.ClientNearCache
-
- getInMemoryFormat() - Method in class com.hazelcast.config.CacheConfig
-
Gets the data type that will be used for storing 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
-
- 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
-
- getInMemoryFormat() - Method in class com.hazelcast.config.RingbufferConfig
-
Gets the InMemoryFormat.
- getInstance() - Method in interface com.hazelcast.hibernate.region.HazelcastRegion
-
- getInstanceMBean() - Method in class com.hazelcast.jmx.ManagementService
-
- 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() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- getInt(int) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- 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.
- 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() - Method in class com.hazelcast.client.config.ClientProperties.ClientProperty
-
- getInteger() - Method in class com.hazelcast.instance.GroupProperties.GroupProperty
-
- getIntegerValue(String, String, int) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- getInterceptorMap() - Method in class com.hazelcast.map.impl.MapContainer
-
- getInterceptors() - Method in class com.hazelcast.map.impl.MapContainer
-
- 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.map.impl.tx.TransactionalMapProxySupport
-
- getInternal(Data) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-
- getInternalThreadGroup() - Method in class com.hazelcast.instance.HazelcastThreadGroup
-
Gets the internal ThreadGroup; so the actual ThreadGroup object.
- getInvalidationMessages() - Method in class com.hazelcast.cache.impl.client.CacheBatchInvalidationMessage
-
- 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.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.executorservice.ExecutorServiceSubmitToAddressMessageTask
-
- getInvocationBuilder(Operation) - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceSubmitToPartitionMessageTask
-
- getInvocationBuilder(Operation) - Method in class com.hazelcast.executor.impl.client.PartitionTargetCallableRequest
-
- getInvocationBuilder(Operation) - Method in class com.hazelcast.executor.impl.client.SpecificTargetCallableRequest
-
- 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.
- getInvocationTimeoutSeconds() - Method in class com.hazelcast.client.config.ClientProperties
-
- getInvocationUsagePercentage() - Method in class com.hazelcast.spi.impl.operationservice.impl.InvocationRegistry
-
- getInvocationUsagePercentage() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-
- getInvocationUsagePercentage() - Method in interface com.hazelcast.spi.impl.operationservice.InternalOperationService
-
Returns the percentage of the the used invocations.
- getIoExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getIOHandler() - 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
-
- 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.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
-
- getJvmId() - Method in class com.hazelcast.web.entryprocessor.DeleteSessionEntryProcessor
-
- getJvmId() - Method in class com.hazelcast.web.entryprocessor.GetAttributeEntryProcessor
-
- getJvmId() - Method in class com.hazelcast.web.entryprocessor.GetAttributeNamesEntryProcessor
-
- getJvmId() - Method in class com.hazelcast.web.entryprocessor.GetSessionStateEntryProcessor
-
- getJvmId() - Method in class com.hazelcast.web.entryprocessor.SessionUpdateEntryProcessor
-
- getJvmIds() - Method in class com.hazelcast.web.SessionState
-
- 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.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.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.util.Int2ObjectHashMap.EntryIterator
-
- getKey() - Method in class com.hazelcast.client.proxy.ClientLockProxy
-
Deprecated.
- getKey() - Method in class com.hazelcast.client.proxy.ClientSemaphoreProxy
-
- getKey() - Method in class com.hazelcast.cluster.client.MemberAttributeChange
-
- getKey() - Method in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLog
-
- getKey() - Method in class com.hazelcast.collection.impl.txnqueue.QueueTransactionLog
-
- 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.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.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 interface com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntry
-
- getKey() - Method in class com.hazelcast.map.impl.NearCacheRecord
-
- getKey() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- 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.MapTransactionLog
-
- 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.MultiMapTransactionLog
-
- getKey() - Method in interface 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.messages.ReplicationMessage
-
- getKey() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedEntryEventFilter
-
- getKey() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- getKey() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventPacketProcessor
-
- 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.KeyAwareTransactionLog
-
- 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.query.impl.QueryEntry
-
- getKeyData() - Method in interface com.hazelcast.query.impl.QueryResultEntry
-
- getKeyData() - Method in class com.hazelcast.query.impl.QueryResultEntryImpl
-
- 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.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
-
- getKeySet() - Method in class com.hazelcast.map.impl.MapKeySet
-
- getKeySet() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeySet
-
- 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
-
Get the key type for this
ICache
.
- getKeyTypeInsideMap(String) - Static method in class com.hazelcast.client.protocol.generator.CodeGenerationUtils
-
- 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.internal.osgi.OSGiScriptEngineFactory
-
- getLanguageVersion() - Method in class com.hazelcast.internal.osgi.OSGiScriptEngineFactory
-
- getLastAccessedTime() - Method in class com.hazelcast.web.HazelcastHttpSession
-
- getLastAccessTime() - Method in interface com.hazelcast.core.EntryView
-
Returns the last access time for the entry.
- 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.LocalMapStatsImpl
-
- getLastAccessTime() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- 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.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
-
- getLastPing() - Method in class com.hazelcast.instance.MemberImpl
-
- getLastRead() - Method in class com.hazelcast.instance.MemberImpl
-
- 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.RecordStatistics
-
- getLastStoredTime() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getLastUpdateTime() - Method in interface com.hazelcast.core.EntryView
-
Returns the last time the value was updated.
- 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.LocalMapStatsImpl
-
- getLastUpdateTime() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- 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
-
- getLastWrite() - Method in class com.hazelcast.instance.MemberImpl
-
- getLatestUpdateHash() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- 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
-
- 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.spi.impl.eventservice.impl.Registration
-
- 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
- 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 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
-
- 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 class com.hazelcast.cluster.impl.ClusterProxy
-
- 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
-
- 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
-
- getLocalReplicationEventCount() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getLocalSocketAddress() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-
- getLocalStartedTaskCount() - Method in class com.hazelcast.jmx.ExecutorServiceMBean
-
- 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
-
- getLock(String) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
- getLock(Object) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
-
Deprecated.
- getLock(Object) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- getLock(String) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
-
- getLock(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the distributed lock instance for the specified key object.
- getLock(Object) - Method in interface com.hazelcast.core.HazelcastInstance
-
- getLock() - Method in class com.hazelcast.hibernate.local.Value
-
- getLock(Object) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
Deprecated.
- getLock(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getLock(Object) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getLock(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getLock(String) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-
- getLock(Object) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
-
Deprecated.
- getLockContainer(int) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- getLockCount(String) - Method in interface com.hazelcast.client.impl.protocol.template.LockCodecTemplate
-
- 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.DefaultRecordStore
-
- getLockOwnerInfo(Data) - Method in interface com.hazelcast.map.impl.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
-
- 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(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() - Method in class com.hazelcast.client.config.ClientProperties.ClientProperty
-
- 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() - Method in class com.hazelcast.instance.GroupProperties.GroupProperty
-
- getLong() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- getLong(int) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- 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, long) - 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 interface com.hazelcast.nio.serialization.PortableContext
-
- getManagedContext() - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- getManagedContext() - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- 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() - Method in class com.hazelcast.client.protocol.generator.MessageFactoryModel
-
- 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.
- 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
-
- getMapContainers() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getMapContextQuerySupport() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getMapDataStore() - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- 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 interface com.hazelcast.map.impl.RecordStore
-
- getMapEntry(Data, long) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- getMapEntry(Data, long) - Method in interface com.hazelcast.map.impl.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
-
- getMapName() - Method in interface com.hazelcast.map.impl.EventData
-
- getMapName() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreContext
-
- 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
-
- 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
-
- 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
-
- 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
-
- getMaxIdleMillis() - Method in class com.hazelcast.map.impl.MapContainer
-
- 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
-
- 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
-
- 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
-
- getMaxSize() - Method in class com.hazelcast.config.QueueConfig
-
Returns the maximum size of the Queue.
- getMaxSizeChecker() - Method in class com.hazelcast.map.impl.eviction.EvictionOperator
-
- 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
-
- 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(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(Address) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- getMember(Address) - Method in interface com.hazelcast.partition.InternalPartitionService
-
- getMember() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapPostJoinOperation.MemberMapPair
-
- getMember() - Method in class com.hazelcast.spi.MembershipServiceEvent
-
Returns the removed or added member.
- 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
-
- 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 interface com.hazelcast.cluster.ClusterService
-
Gets the collection of members.
- getMemberList() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- 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() - Method in class com.hazelcast.client.util.AbstractLoadBalancer
-
- getMembers() - Method in class com.hazelcast.cluster.client.ClientInitialMembershipEvent
-
Returns member list after initial registration.
- getMembers() - Method in interface com.hazelcast.cluster.ClusterService
-
Returns a collection of all members part of the cluster.
- getMembers() - Method in class com.hazelcast.cluster.impl.ClusterProxy
-
- getMembers() - 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
-
- 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
-
- 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() - Method in class com.hazelcast.config.MapConfig
-
- 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
-
- 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.internal.osgi.OSGiScriptEngineFactory
-
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CacheGetAllRequest
-
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-
- getMethodName() - Method in class com.hazelcast.client.impl.client.ClientRequest
-
- 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.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.CacheCreateConfigMessageTask
-
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
-
- 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.CacheRemoveEntryListenerMessageTask
-
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
-
- 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.GetDistributedObjectMessageTask
-
- 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.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.MapGetAsyncMessageTask
-
- 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.MapPutAsyncMessageTask
-
- 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.MapRemoveAsyncMessageTask
-
- 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.MultiMapCountMessageTask
-
- 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.RegisterMembershipListenerMessageTask
-
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
-
- getMethodName() - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistrubtedObjectListenerMessageTask
-
- 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.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.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.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.MapEntrySetRequest
-
- 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.MapKeySetRequest
-
- 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.map.impl.client.MapValuesRequest
-
- 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.topic.impl.client.AddMessageListenerRequest
-
- getMethodName() - Method in class com.hazelcast.topic.impl.client.PublishRequest
-
- getMethodName() - Method in class com.hazelcast.topic.impl.client.RemoveMessageListenerRequest
-
- 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
-
- getMimeTypes() - Method in class com.hazelcast.internal.osgi.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.
- 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
-
- 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 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
this
NearCache
instance.
- getName() - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-
- getName() - Method in class com.hazelcast.client.config.ClientProperties.ClientProperty
-
- 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.protocol.generator.CodecModel.EventModel
-
- getName() - Method in class com.hazelcast.client.protocol.generator.CodecModel
-
- getName() - Method in class com.hazelcast.client.protocol.generator.CodecModel.ParameterModel
-
- getName() - Method in class com.hazelcast.client.protocol.generator.MessageTypeEnumModel
-
- getName() - Method in class com.hazelcast.client.protocol.generator.MessageTypeEnumModel.ParameterModel
-
- getName() - Method in class com.hazelcast.client.proxy.txn.AbstractClientTxnCollectionProxy
-
- getName() - Method in class com.hazelcast.client.proxy.txn.ClientTxnMapProxy
-
- getName() - Method in class com.hazelcast.client.proxy.txn.ClientTxnMultiMapProxy
-
- getName() - Method in class com.hazelcast.client.proxy.txn.ClientTxnQueueProxy
-
- getName() - Method in class com.hazelcast.client.spi.ClientProxy
-
- getName() - Method in class com.hazelcast.client.txn.proxy.AbstractClientTxnCollectionProxy
-
- getName() - Method in class com.hazelcast.client.txn.proxy.ClientTxnMapProxy
-
- getName() - Method in class com.hazelcast.client.txn.proxy.ClientTxnMultiMapProxy
-
- getName() - Method in class com.hazelcast.client.txn.proxy.ClientTxnQueueProxy
-
- 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.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
-
- 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.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
-
- 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 class com.hazelcast.instance.GroupProperties.GroupProperty
-
- getName() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getName() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getName() - Method in class com.hazelcast.instance.Node
-
- getName() - Method in class com.hazelcast.internal.metrics.impl.GaugeImpl
-
- getName() - Method in interface com.hazelcast.internal.metrics.Metric
-
Gets the name that identifies this metric.
- 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.operation.AddInterceptorOperation
-
- getName() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- getName() - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
-
- getName() - Method in interface com.hazelcast.map.impl.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.ObjectMultiMapProxy
-
- 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.messages.MultiReplicationMessage
-
- getName() - Method in class com.hazelcast.replicatedmap.impl.messages.ReplicationMessage
-
- getName() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapInitChunkOperation
-
- getName() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapPostJoinOperation.MemberMapPair
-
- 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.DistributedObjectEventPacket
-
- getName() - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
-
- getName() - Method in interface com.hazelcast.spi.NamedOperation
-
Returns the name of the distributed data structure.
- getName() - Method in class com.hazelcast.spi.ServiceInfo
-
- 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 metric names.
- getNames() - Method in class com.hazelcast.internal.osgi.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.
- getNativeCache() - Method in class com.hazelcast.spring.cache.HazelcastCache
-
- getNativeDataStorage() - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- getNativeDataStorage() - Method in interface com.hazelcast.instance.NodeExtension
-
Deprecated.
- 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(String) - Method in class com.hazelcast.map.impl.NearCacheProvider
-
- 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
-
- 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
-
- 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.nearcache.ClientHeapNearCache
-
- getNearCacheStats() - Method in interface com.hazelcast.client.nearcache.ClientNearCache
-
- getNearCacheStats() - Method in class com.hazelcast.map.impl.NearCache
-
- 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.
- getNetworkConfig() - Method in class com.hazelcast.client.config.ClientConfig
-
- getNetworkConfig() - Method in class com.hazelcast.config.Config
-
- 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.spi.AbstractDistributedObject
-
Gets the node engine.
- getNodeEngine() - Method in class com.hazelcast.spi.Operation
-
- getNodeExtension() - Method in class com.hazelcast.instance.Node
-
- getNodeMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getNodeName() - Method in enum com.hazelcast.config.PermissionConfig.PermissionType
-
- 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
-
- getNumberOfAffectedEntries() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-
- getNumberOfEntries() - Method in class com.hazelcast.map.impl.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
-
Returns the identifier of related DistributedObject.
- 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.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
-
- getOffHeapStorage() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getOffHeapStorage() - Method in interface com.hazelcast.spi.NodeEngine
-
- 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
-
- getOperationExecutor() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-
- getOperationExecutor() - Method in interface com.hazelcast.spi.impl.operationservice.InternalOperationService
-
- 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
-
- 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, Authenticator) - Method in interface com.hazelcast.client.connection.ClientConnectionManager
-
- getOrConnect(Address, Authenticator) - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-
- getOrConnect(Address) - Method in interface com.hazelcast.nio.ConnectionManager
-
- getOrConnect(Address, boolean) - Method in interface com.hazelcast.nio.ConnectionManager
-
- getOrConnect(Address) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- getOrConnect(Address, boolean) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- getOrCreateCache(String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- getOrCreateCache(String, CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getOrCreateCache(String) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-
- getOrCreateCache(String, int) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- getOrCreateCollectionContainer(int, String) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- getOrCreateCollectionWrapper() - Method in class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-
- 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
-
- getOrCreateListContainer() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
-
- getOrCreateMultiMapContainer(String) - Method in class com.hazelcast.multimap.impl.MultiMapPartitionContainer
-
- 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.
- getOrCreateProxy(String, String) - Method in class com.hazelcast.client.spi.ProxyManager
-
- getOrCreateRegistry(String) - Method in class com.hazelcast.spi.impl.proxyservice.impl.ProxyServiceImpl
-
- getOrDefault(int, Int2ObjectHashMap.Supplier<V>) - Method in class com.hazelcast.client.impl.protocol.util.Int2ObjectHashMap
-
Get a value for a given key, or if it does ot exist then default the value via a
Int2ObjectHashMap.Supplier
and put it in the map.
- getOrderKey() - Method in class com.hazelcast.cache.impl.CacheEventContext
-
- getOrderLock(String) - Method in class com.hazelcast.topic.impl.TopicService
-
- getOrigin() - Method in class com.hazelcast.cache.impl.CacheEventContext
-
- getOrigin() - Method in class com.hazelcast.replicatedmap.impl.messages.ReplicationMessage
-
- getOriginalSession() - Method in class com.hazelcast.web.HazelcastHttpSession
-
- getOriginalSessionId() - Method in class com.hazelcast.web.HazelcastHttpSession
-
- 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
-
- 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
-
- getOutOfMemoryErrorCount() - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
-
Gets the number of OutOfMemoryErrors that have been reported.
- getOutputStatement(String) - Method in class com.hazelcast.internal.osgi.OSGiScriptEngineFactory
-
- 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.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.AbstractSelectionHandler
-
Get IOSelector currently owning this handler.
- getOwner() - Method in interface com.hazelcast.nio.tcp.MigratableHandler
-
Get IOSelector currently owning this handler.
- getOwner() - Method in class com.hazelcast.partition.PartitionServiceProxy.PartitionProxy
-
- getOwnerConnectionAddress() - Method in interface com.hazelcast.client.spi.ClientClusterService
-
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.
- getOwnerUuid() - Method in class com.hazelcast.client.impl.client.ClientPrincipal
-
- getOwnerUuid() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-
- getOwnerUuid() - Method in interface com.hazelcast.transaction.impl.TransactionSupport
-
- getPackageName() - Method in class com.hazelcast.client.protocol.generator.CodecModel
-
- getPackageName() - Method in class com.hazelcast.client.protocol.generator.MessageTypeEnumModel
-
- getPackageNameFromQualifiedName(String) - Static method in class com.hazelcast.client.protocol.generator.CodeGenerationUtils
-
- getPacketCount() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-
- getPacketTransceiver() - 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.internal.osgi.OSGiScriptEngineFactory
-
- getParameters() - Method in class com.hazelcast.cache.impl.client.CacheGetAllRequest
-
- getParameters() - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-
- 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.AddDistributedObjectListenerMessageTask
-
- 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.CacheCreateConfigMessageTask
-
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
-
- 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.CacheRemoveEntryListenerMessageTask
-
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
-
- 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.GetDistributedObjectMessageTask
-
- 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.ListRemoveListenerMessageTask
-
- 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.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.MapGetAsyncMessageTask
-
- 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.MapPutAsyncMessageTask
-
- 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.MapRemoveAsyncMessageTask
-
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveEntryListenerMessageTask
-
- 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.MapRemovePartitionLostListenerMessageTask
-
- 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.MultiMapCountMessageTask
-
- 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.MultiMapRemoveEntryListenerMessageTask
-
- 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.QueueRemoveListenerMessageTask
-
- 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.RegisterMembershipListenerMessageTask
-
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
-
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistrubtedObjectListenerMessageTask
-
- getParameters() - Method in class com.hazelcast.client.impl.protocol.task.RemovePartitionLostListenerMessageTask
-
- 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.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.ReplicatedMapRemoveEntryListenerMessageTask
-
- 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.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.SetRemoveListenerMessageTask
-
- 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.topic.TopicRemoveMessageListenerMessageTask
-
- 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.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.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.ClientReplicatedMapRemoveEntryListenerRequest
-
- getParameters() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveRequest
-
- getParameters() - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-
- getParameters() - Method in class com.hazelcast.topic.impl.client.PublishRequest
-
- getParams() - Method in class com.hazelcast.client.protocol.generator.MessageTypeEnumModel
-
- getParentName() - Method in class com.hazelcast.client.protocol.generator.CodecModel
-
- getPartition() - Method in class com.hazelcast.cache.impl.client.CacheIterateRequest
-
- 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.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.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
-
- 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 interface com.hazelcast.nio.serialization.Data
-
Returns partition hash calculated for serialized object.
- getPartitionHash() - Method in class com.hazelcast.nio.serialization.DefaultData
-
- 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.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.MapPartitionEventData
-
- getPartitionId() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.entry.DelayedEntry
-
- getPartitionId() - Method in class com.hazelcast.map.impl.PartitionContainer
-
- getPartitionId() - Method in interface com.hazelcast.map.impl.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 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() - 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.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.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
-
- 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 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.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 interface com.hazelcast.client.impl.protocol.template.ClientMessageTemplate
-
- getPartitions() - Method in class com.hazelcast.client.proxy.PartitionServiceProxy
-
- getPartitions() - Method in interface com.hazelcast.core.PartitionService
-
Returns a set containing all the
Partition
s 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
-
- getPendingInvocationCount() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-
- getPendingInvocationCount() - Method in interface com.hazelcast.spi.impl.operationservice.InternalOperationService
-
Gets the current number of pending invocations.
- 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
-
- 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 interface com.hazelcast.nio.serialization.SerializationService
-
- getPortableContext() - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- 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.
- getPortCount() - Method in class com.hazelcast.config.NetworkConfig
-
Returns the maximum number of ports allowed to try to bind on.
- getPossibleInetAddressesFor(Inet6Address) - Static method in class com.hazelcast.util.AddressUtil
-
- getPossibleSocketAddresses(InetAddress, int, String) - 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.MapKeySetWithPagingPredicateMessageTask
-
- getPredicate() - Method in class com.hazelcast.client.impl.protocol.task.map.MapKeySetWithPredicateMessageTask
-
- 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.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.QueryEventFilter
-
- getPredicate() - Method in class com.hazelcast.query.PagingPredicate
-
- getPredicate() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedQueryEventFilter
-
- 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.
- 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.
- getPrivateIpAddresses() - Method in class com.hazelcast.aws.AWSClient
-
- 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.internal.osgi.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.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.
- getProperty(String) - Method in class com.hazelcast.client.config.ClientConfig
-
Gets a property already set or from system properties if not exists.
- getProperty(String) - 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.
- 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.
- 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.
- getPublisherAddress() - Method in class com.hazelcast.topic.impl.reliable.ReliableTopicMessage
-
- 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 QueryCacheConfig
instances defined on this MapConfig
- getQueryCacheConfigs() - Method in class com.hazelcast.config.MapConfigReadOnly
-
- getQueryExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getQueryString(Map<String, String>) - Static method in class com.hazelcast.aws.utility.CloudyUtility
-
- 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
-
- getQueueConfig(String) - Method in class com.hazelcast.config.Config
-
- getQueueConfigs() - Method in class com.hazelcast.config.Config
-
- getQueueService() - Method in class com.hazelcast.collection.impl.queue.operations.QueueOperation
-
- getQueueSize() - Method in class com.hazelcast.config.JobTrackerConfig
-
- 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() - 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
-
- 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.nio.serialization.DefaultPortableReader
-
- getRawDataInput() - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- getRawDataOutput() - Method in class com.hazelcast.nio.serialization.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.config.ReliableTopicConfig
-
Gets the maximum number of items to read in a batch.
- getReadEvents() - Method in class com.hazelcast.nio.tcp.InSelectorImpl
-
Returns the current number of read events that have been processed by this InSelectorImpl.
- getReadHandler() - Method in class com.hazelcast.client.connection.nio.ClientConnection
-
- getReadHandler() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- getReadonlyMap() - Method in class com.hazelcast.map.impl.NearCache
-
- 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.
- 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.DefaultRecordStore
-
- getRecord(Data) - Method in interface com.hazelcast.map.impl.RecordStore
-
- getRecordCollection(NodeEngine) - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
-
- getRecordFactory() - Method in class com.hazelcast.jca.ConnectionFactoryImpl
-
- getRecordFactory() - 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
-
- getRecordMap() - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- getRecordMap() - Method in interface com.hazelcast.map.impl.RecordStore
-
Returns records map.
- 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.DefaultRecordStore
-
- getRecordOrNull(Data) - Method in interface com.hazelcast.map.impl.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(MultiResultSet, Set<Comparable>) - Method in interface com.hazelcast.query.impl.IndexStore
-
- getRecords(Comparable) - Method in class com.hazelcast.query.impl.SortedIndexStore
-
- getRecords(MultiResultSet, Set<Comparable>) - Method in class com.hazelcast.query.impl.SortedIndexStore
-
- getRecords(Comparable) - Method in class com.hazelcast.query.impl.UnsortedIndexStore
-
- getRecords(MultiResultSet, Set<Comparable>) - Method in class com.hazelcast.query.impl.UnsortedIndexStore
-
- 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(int, String) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getRecordStore(String) - Method in class com.hazelcast.map.impl.PartitionContainer
-
- getRecordValue(R) - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-
- getRecordValues() - Method in class com.hazelcast.query.impl.IndexImpl
-
- 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
-
- 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
-
- getRegistrationId() - Method in class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
-
- getRegistrationIdMap() - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceSegment
-
- 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.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(String) - Method in interface com.hazelcast.client.impl.protocol.template.LockCodecTemplate
-
- 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
null
if 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) - 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.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.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() - Method in class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-
- getReplicatedRecordStore() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-
- getReplicatedRecordStore(String, boolean) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- getReplicationDelayMillis() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- getReplicationEventCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getReplicationEventCount() - Method in interface com.hazelcast.monitor.LocalReplicatedMapStats
-
- getReplicationImpl() - Method in class com.hazelcast.config.WanTargetClusterConfig
-
- getReplicationImplObject() - Method in class com.hazelcast.config.WanTargetClusterConfig
-
- getReplicationMessages() - Method in class com.hazelcast.replicatedmap.impl.messages.MultiReplicationMessage
-
- getReplicationPublisher() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- getReplicatorExecutorService() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- getRequest() - Method in class com.hazelcast.client.spi.impl.ClientInvocation
-
- getRequest() - Method in class com.hazelcast.client.spi.impl.ClientInvocationFuture
-
- 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
-
- getRequestParams() - Method in class com.hazelcast.client.protocol.generator.CodecModel
-
- 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.CacheClearRequest
-
- 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.CacheGetAllRequest
-
- 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.CacheRemoveEntryListenerRequest
-
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheRemoveInvalidationListenerRequest
-
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheSizeRequest
-
- 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.DistributedObjectListenerRequest
-
- 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.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.CacheCreateConfigMessageTask
-
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
-
- 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.CacheRemoveEntryListenerMessageTask
-
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
-
- 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.GetDistributedObjectMessageTask
-
- 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.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.MapGetAsyncMessageTask
-
- 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.MapRemoveAsyncMessageTask
-
- 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.MultiMapCountMessageTask
-
- 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.RegisterMembershipListenerMessageTask
-
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
-
- getRequiredPermission() - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistrubtedObjectListenerMessageTask
-
- 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.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.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.MapEntrySetRequest
-
- 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.MapKeySetRequest
-
- 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.map.impl.client.MapValuesRequest
-
- 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.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.protocol.generator.CodecModel
-
- getResponse() - Method in class com.hazelcast.cluster.impl.operations.AuthorizationOperation
-
- 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.PrepareMergeOperation
-
- 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.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.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.EntryBackupOperation
-
- 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.MapEntrySetOperation
-
- 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.MapKeySetOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.MapSizeOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.MapValuesOperation
-
- 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.QueryOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.QueryPartitionOperation
-
- 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.operation.WanOriginatedDeleteOperation
-
- 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.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.Operation
-
- getResponse() - Method in class com.hazelcast.transaction.impl.BeginTxBackupOperation
-
- getResponse() - Method in class com.hazelcast.transaction.impl.BroadcastTxRollbackOperation
-
- getResponse() - Method in class com.hazelcast.transaction.impl.PurgeTxBackupOperation
-
- getResponse() - Method in class com.hazelcast.transaction.impl.ReplicateTxOperation
-
- getResponse() - Method in class com.hazelcast.transaction.impl.RollbackTxBackupOperation
-
- getResponse() - Method in class com.hazelcast.transaction.impl.xa.ClearRemoteTransactionBackupOperation
-
- getResponse() - Method in class com.hazelcast.transaction.impl.xa.ClearRemoteTransactionOperation
-
- getResponse() - Method in class com.hazelcast.transaction.impl.xa.CollectRemoteTransactionsOperation
-
- getResponse() - Method in class com.hazelcast.transaction.impl.xa.FinalizeRemoteTransactionBackupOperation
-
- getResponse() - Method in class com.hazelcast.transaction.impl.xa.FinalizeRemoteTransactionOperation
-
- getResponse() - Method in class com.hazelcast.transaction.impl.xa.PutRemoteTransactionBackupOperation
-
- getResponse() - Method in class com.hazelcast.transaction.impl.xa.PutRemoteTransactionOperation
-
- getResponseHandler() - Method in class com.hazelcast.spi.Operation
-
- getResponseParams() - Method in class com.hazelcast.client.protocol.generator.CodecModel
-
- getResponseQueueSize() - Method in class com.hazelcast.jmx.OperationServiceMBean
-
- getResponseQueueSize() - Method in class com.hazelcast.spi.impl.operationexecutor.classic.ClassicOperationExecutor
-
- getResponseQueueSize() - Method in interface com.hazelcast.spi.impl.operationexecutor.OperationExecutor
-
Deprecated.
- getResponseQueueSize() - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-
- getResponseQueueSize() - Method in interface com.hazelcast.spi.OperationService
-
Deprecated.
- getResult() - Method in class com.hazelcast.map.impl.QueryResult
-
- getResult() - Method in class com.hazelcast.mapreduce.impl.operation.GetResultOperation
-
- getResult() - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-
- 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
-
- 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
-
- getRetryable() - Method in class com.hazelcast.client.protocol.generator.CodecModel
-
- getRetryCount() - Method in class com.hazelcast.config.JobTrackerConfig
-
- 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(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
-
- 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
-
- getScheduleStartTimeInNanos() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
-
- 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.internal.osgi.OSGiScriptEngineFactory
-
- getScriptEngineManager() - Static method in class com.hazelcast.internal.management.ScriptEngineManagerContext
-
- getSecond() - Method in class com.hazelcast.mapreduce.aggregation.impl.AvgTuple
-
- 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.AbstractSelectionHandler
-
- getSelector() - Method in class com.hazelcast.nio.tcp.AbstractIOSelector
-
- getSelector() - Method in interface com.hazelcast.nio.tcp.IOSelector
-
- getSelectorThreadCount() - Method in interface com.hazelcast.nio.IOService
-
- getSelectorThreadCount() - Method in class com.hazelcast.nio.NodeIOService
-
- 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
-
- getSender() - Method in class com.hazelcast.mapreduce.impl.notification.LastChunkNotification
-
- 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 class com.hazelcast.client.connection.nio.ClientConnection
-
- 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 class com.hazelcast.mapreduce.impl.JobPartitionStateArraySerializerHook
-
- getSerializationType() - Method in class com.hazelcast.mapreduce.impl.JobPartitionStateSerializerHook
-
- getSerializationType() - Method in interface com.hazelcast.nio.serialization.SerializerHook
-
Returns the actual class type of the serialized object
- getSerializationType() - Method in class com.hazelcast.nio.serialization.serializers.ArrayListSerializerHook
-
- getSerializationType() - Method in class com.hazelcast.nio.serialization.serializers.LinkedListSerializerHook
-
- getSerializerConfigs() - Method in class com.hazelcast.config.SerializationConfig
-
- 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() - Method in class com.hazelcast.spi.Operation
-
- getService() - Method in class com.hazelcast.spi.ServiceInfo
-
- 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
-
- getServiceInfos(Class) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- 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.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.CacheRemoveEntryListenerRequest
-
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheRemoveInvalidationListenerRequest
-
- 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.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.DistributedObjectListenerRequest
-
- 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.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.CacheClearMessageTask
-
- 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.CacheGetAllMessageTask
-
- 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.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.GetDistributedObjectMessageTask
-
- 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.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.MapEntrySetMessageTask
-
- 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.MapGetAsyncMessageTask
-
- 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.MapKeySetMessageTask
-
- 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.MapRemoveAsyncMessageTask
-
- 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.map.MapValuesMessageTask
-
- 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.MultiMapCountMessageTask
-
- 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.RegisterMembershipListenerMessageTask
-
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
-
- getServiceName() - Method in class com.hazelcast.client.impl.protocol.task.RemoveDistrubtedObjectListenerMessageTask
-
- 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.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.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.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.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.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.MapEntrySetRequest
-
- 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.MapKeySetRequest
-
- 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